2025.09.09 14:23:00.131614 [ 408 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.09.09 14:23:00.131808 [ 408 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.09.09 14:23:00.164447 [ 408 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.09 14:23:00.166431 [ 408 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.09 14:23:23.852070 [ 408 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.09.09 14:23:23.853155 [ 408 ] {} KeeperLogStore: Removing all changelogs 2025.09.09 14:23:23.854843 [ 408 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.09 14:23:23.863729 [ 408 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.09 14:23:23.863820 [ 408 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.09 14:23:23.915139 [ 1111 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.09 14:23:24.208001 [ 408 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.09.09 14:23:24.208125 [ 408 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.09.09 14:23:24.965301 [ 408 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.09 14:23:38.553505 [ 412 ] {43f48920-4247-4e2b-b326-0aa171acf829} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.09.09 14:23:49.425326 [ 412 ] {05155714-3c9d-4a45-bc7b-a0e928081609} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.09.09 14:23:59.764860 [ 1125 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.09.09 14:24:02.428972 [ 1372 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.09.09 14:24:02.429087 [ 1372 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.09.09 14:24:02.453633 [ 1372 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.09 14:24:02.454874 [ 1372 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.09 14:24:33.660492 [ 1372 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.09 14:24:33.737288 [ 1372 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.09 14:24:33.737414 [ 1372 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.09 14:24:33.789070 [ 2118 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.09 14:24:36.535343 [ 1372 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.09 14:25:19.012588 [ 2143 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.09.09 14:25:19.012716 [ 2143 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.09.09 14:25:21.167412 [ 1376 ] {1a6c78d2-0e9d-4bd1-adad-dee844f641db} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1114112 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column RefererRegions): (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 68 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35548) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff78764 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000838465c 11. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:143: DB::SerializationArray::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 @ 0x0000000032660170 12. ./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) @ 0x0000000039cec8a2 13. ./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>>&) @ 0x0000000039ceabe6 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c99152 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cbc936 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb5073 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2fe06 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf59cb4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21f50 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 30. ? @ 0x00007f49289baac3 31. ? @ 0x00007f4928a4c850 2025.09.09 14:25:21.571116 [ 2212 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 59 entries up to offset 7460: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 18.47 GiB (attempt to allocate chunk of 4369523 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff78764 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x00000000201898aa 9. ./src/IO/BufferWithOwnMemory.h:159: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000020206e93 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x0000000020204ead 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x0000000020593a28 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&) @ 0x0000000032ec8023 13. ./build_docker/./src/Disks/DiskLocal.cpp:0: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000032eb0718 14. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x0000000032f03663 15. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:137: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000393ad991 16. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:141: DB::IMergeTreeDataPart::MinMaxIndex::store(std::vector> const&, std::vector, std::allocator>> const&, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&) const @ 0x0000000039444f72 17. ./contrib/llvm-project/libcxx/include/vector:438: DB::IMergeTreeDataPart::MinMaxIndex::store(DB::MergeTreeData const&, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&) const @ 0x0000000039443aa9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000039e2b649 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000039e26ba2 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f0600c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef974a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a3a08f5 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb2a6c4 24. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b803ce9 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b8024a7 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aecc419 31. ./build_docker/./src/Interpreters/SystemLog.cpp:0: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000353f0090 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:25:24.561092 [ 1376 ] {1a6c78d2-0e9d-4bd1-adad-dee844f641db} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1114112 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column RefererRegions): (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 68 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff78764 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000838465c 11. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:143: DB::SerializationArray::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 @ 0x0000000032660170 12. ./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) @ 0x0000000039cec8a2 13. ./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>>&) @ 0x0000000039ceabe6 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c99152 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cbc936 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb5073 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2fe06 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf59cb4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21f50 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 30. ? @ 0x00007f49289baac3 31. ? @ 0x00007f4928a4c850 2025.09.09 14:25:43.767642 [ 1376 ] {ab5edc06-14a2-4f94-8602-4d02e7de7a9f} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1179520 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column UTMContent): (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 156 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57188) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff78764 10. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000003283083d 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: 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 @ 0x0000000032639a70 12. ./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) @ 0x0000000039cec8a2 13. ./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>>&) @ 0x0000000039ceabe6 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c99152 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cbc936 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb5073 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2fe06 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf59cb4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21f50 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 30. ? @ 0x00007f49289baac3 31. ? @ 0x00007f4928a4c850 2025.09.09 14:25:45.792030 [ 1376 ] {ab5edc06-14a2-4f94-8602-4d02e7de7a9f} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1179520 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column UTMContent): (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 156 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff78764 10. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000003283083d 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: 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 @ 0x0000000032639a70 12. ./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) @ 0x0000000039cec8a2 13. ./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>>&) @ 0x0000000039ceabe6 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c99152 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cbc936 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb5073 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2fe06 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf59cb4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21f50 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 30. ? @ 0x00007f49289baac3 31. ? @ 0x00007f4928a4c850 2025.09.09 14:26:04.017130 [ 2143 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.09.09 14:26:04.017219 [ 2143 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.09.09 14:26:06.842817 [ 2244 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 2856 entries up to offset 32808: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 16.60 GiB (attempt to allocate chunk of 4375347 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff78764 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x00000000201898aa 9. ./src/IO/BufferWithOwnMemory.h:159: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x00000000320e5408 10. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:84: std::shared_ptr std::allocate_shared[abi:v15007], DB::HashingWriteBuffer&, std::shared_ptr&, void>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x00000000399b74ed 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: void std::__function::__policy_invoker::__call_impl::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000399af57b 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000032637b02 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263850d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x00000000399a56d5 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399a4bd5 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000003997aa7e 17. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:179: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399c09bd 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039e22a8f 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool, bool, DB::WriteSettings>(std::shared_ptr&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool&&, bool&&, DB::WriteSettings&&) @ 0x0000000039f17b09 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f02499 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef974a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a3a08f5 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb2a6c4 24. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b803ce9 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b8024a7 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aecc419 31. ./build_docker/./src/Interpreters/SystemLog.cpp:0: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000352f5ff0 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:26:08.216964 [ 1376 ] {c7875fe8-2908-49d4-9cc8-c52bf6629229} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1310720 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45584) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 9. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff793a5 10. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000095e5592 11. ./build_docker/./src/Columns/ColumnVector.cpp:521: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000378d5eeb 12. ./src/Columns/IColumn.h:0: DB::ColumnArray::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x0000000036fbf768 13. ./src/Processors/Merges/Algorithms/MergedData.h:58: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000003bb6baaf 14. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:103: DB::CollapsingSortedAlgorithm::insertRows() @ 0x000000003bb64987 15. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x000000003bb68127 16. ./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&) @ 0x0000000039ef71d7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039efd97a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef974a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a3a08f5 20. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb2a6c4 21. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b803ce9 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b8024a7 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 2025.09.09 14:26:09.054200 [ 1376 ] {c7875fe8-2908-49d4-9cc8-c52bf6629229} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1310720 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 9. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff793a5 10. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000095e5592 11. ./build_docker/./src/Columns/ColumnVector.cpp:521: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000378d5eeb 12. ./src/Columns/IColumn.h:0: DB::ColumnArray::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x0000000036fbf768 13. ./src/Processors/Merges/Algorithms/MergedData.h:58: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000003bb6baaf 14. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:103: DB::CollapsingSortedAlgorithm::insertRows() @ 0x000000003bb64987 15. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x000000003bb68127 16. ./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&) @ 0x0000000039ef71d7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039efd97a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef974a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a3a08f5 20. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb2a6c4 21. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b803ce9 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b8024a7 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 2025.09.09 14:26:15.564863 [ 2133 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.09.09 14:26:18.387823 [ 2874 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.09.09 14:26:18.387964 [ 2874 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.09.09 14:26:18.522867 [ 2874 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.09.09 14:26:18.528177 [ 2874 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.09 14:26:18.530019 [ 2874 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.09 14:26:44.267699 [ 2874 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.09 14:26:44.275594 [ 2874 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.09 14:26:44.275720 [ 2874 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.09 14:26:44.327511 [ 3587 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.09 14:26:47.263720 [ 2874 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.09 14:26:49.895696 [ 2879 ] {53eae9a9-be2f-4fe2-a686-a697271e4c16} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51944) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:26:49.897437 [ 2879 ] {53eae9a9-be2f-4fe2-a686-a697271e4c16} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:26:55.899879 [ 2879 ] {586af872-77d9-4502-936d-bf445eb1f1d6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51956) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f877 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:26:55.901458 [ 2879 ] {586af872-77d9-4502-936d-bf445eb1f1d6} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f877 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:27:10.765494 [ 3860 ] {9407ed8e-a396-43c5-950a-39d91fcef72d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52098) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f877 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:27:10.767973 [ 3860 ] {9407ed8e-a396-43c5-950a-39d91fcef72d} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f877 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:11.260536 [ 2880 ] {d0d8b553-de60-4a0e-8cde-c21c447745a7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52096) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:11.262693 [ 2880 ] {d0d8b553-de60-4a0e-8cde-c21c447745a7} DynamicQueryHandler: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:12.852493 [ 2880 ] {81660db7-6365-4f55-94fa-324fdbee8076} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52376) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f877 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:27:12.878662 [ 2880 ] {81660db7-6365-4f55-94fa-324fdbee8076} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f877 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:13.232526 [ 2880 ] {549eaa4b-0bd1-4a0b-98b6-b1cead8b2ed2} 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.10505.altinitytest (altinity build)) (from [::1]:52396) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:13.234276 [ 2880 ] {549eaa4b-0bd1-4a0b-98b6-b1cead8b2ed2} DynamicQueryHandler: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:13.349142 [ 2879 ] {cd883a36-52f7-4baf-a0c3-5b4a0c14474c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37314) (comment: 00033_aggregate_key_string.sql) (in query: SELECT SearchPhrase AS k1, count() AS c FROM test.hits GROUP BY k1 ORDER BY c DESC, k1 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:13.586967 [ 2879 ] {cd883a36-52f7-4baf-a0c3-5b4a0c14474c} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:14.776349 [ 3860 ] {12e9938e-a6dd-49d5-9169-c5c373047626} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52410) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:14.778873 [ 3860 ] {12e9938e-a6dd-49d5-9169-c5c373047626} DynamicQueryHandler: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:14.810287 [ 3870 ] {cd059531-f03c-45f1-ae3c-08c92c326698} 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.10505.altinitytest (altinity build)) (from [::1]:52526) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:14.812200 [ 3870 ] {cd059531-f03c-45f1-ae3c-08c92c326698} DynamicQueryHandler: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:15.272197 [ 3860 ] {b5d9c0a5-0c32-4160-bc62-c26013eafd64} 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.10505.altinitytest (altinity build)) (from [::1]:52582) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:15.274599 [ 3860 ] {b5d9c0a5-0c32-4160-bc62-c26013eafd64} DynamicQueryHandler: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:17.081620 [ 3962 ] {0e59c3e6-a1c3-48cd-8997-d4dbda1029fc} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52594) (comment: 00181_cross_join_compression.sql) (in query: DROP DATABASE IF EXISTS test_krjl7vu7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 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>>>&) @ 0x00000000349384ad 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:17.083442 [ 3962 ] {0e59c3e6-a1c3-48cd-8997-d4dbda1029fc} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 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>>>&) @ 0x00000000349384ad 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:17.972392 [ 3860 ] {f55e0442-ae35-4d13-aebc-90d7640ea8a5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45806) (comment: 02293_formats_json_columns.sh) (in query: insert into test_02293 select number, 'String', [(range(number % 3), 'String'), (range(number % 4), 'gnirtS')] from numbers(5) settings max_block_size=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./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*) @ 0x000000003ae7acd9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:17.976394 [ 3860 ] {f55e0442-ae35-4d13-aebc-90d7640ea8a5} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./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*) @ 0x000000003ae7acd9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:18.991125 [ 4042 ] {18d348d2-a949-43a4-8fce-81acb8bf739e} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45846) (comment: 00056_view.sql) (in query: DROP TABLE test.view;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:18.992732 [ 4042 ] {18d348d2-a949-43a4-8fce-81acb8bf739e} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:19.451301 [ 4082 ] {597414f6-64a6-4a25-9f24-1886327e5f0b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45830) (comment: 00157_cache_dictionary.sql) (in query: CREATE TABLE test.hits_1m AS test.hits ENGINE = MergeTree PARTITION BY toYYYYMM(EventDate) ORDER BY (CounterID, EventDate, intHash32(UserID)) SAMPLE BY intHash32(UserID) SETTINGS storage_policy = 'default', index_granularity = 11581, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 418450519, compact_parts_max_bytes_to_buffer = 435791649, compact_parts_max_granules_to_buffer = 85, compact_parts_merge_max_bytes_to_prefetch_part = 24592810, merge_max_block_size = 23706, old_parts_lifetime = 480., 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 = 3728646721, index_granularity_bytes = 23077563, concurrent_part_removal_threshold = 78, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 56468, primary_key_compress_block_size = 21779), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:19.453819 [ 4082 ] {597414f6-64a6-4a25-9f24-1886327e5f0b} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:20.656640 [ 3860 ] {7b39cbfc-c357-4680-8b20-f4f43cd3617c} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45948) (comment: 00061_storage_buffer.sql) (in query: DROP TABLE test.hits_buffer;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:20.657779 [ 3860 ] {7b39cbfc-c357-4680-8b20-f4f43cd3617c} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:21.088099 [ 4041 ] {fb97de9b-4f19-490a-b349-87a260452f03} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=733, jobs=715). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45938) (comment: 02293_formats_json_columns.sh) (in query: select * from test_02293 order by a format JSONColumns), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:21.089750 [ 4041 ] {fb97de9b-4f19-490a-b349-87a260452f03} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=733, jobs=715). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:22.683320 [ 2879 ] {9a8a68c0-e788-402f-9e1d-8b1db3c7352b} executeQuery: Code: 47. DB::Exception: JOIN GLOBAL LEFT JOIN ... USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46026) (comment: 01474_bad_global_join.sql) (in query: SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f9e97 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5106: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f022a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:22.684366 [ 2879 ] {9a8a68c0-e788-402f-9e1d-8b1db3c7352b} TCPHandler: Code: 47. DB::Exception: JOIN GLOBAL LEFT JOIN ... USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000334f9e97 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5106: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f022a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:22.789042 [ 4041 ] {912649f6-6667-4251-a2dd-4d2309b7d1d8} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONColumns format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 25000 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46076) (comment: 02293_formats_json_columns.sh) (in query: desc file(data_02293, JSONColumns)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:27:22.790234 [ 4041 ] {912649f6-6667-4251-a2dd-4d2309b7d1d8} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONColumns format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 25000 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:27:23.091449 [ 2880 ] {74ec0642-fcb6-4b60-a73d-fc31db422d4b} 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.10505.altinitytest (altinity build)) (from [::1]:46110) (comment: 00023_totals_limit.sql) (in query: SELECT goals_alias.ID AS `ym:s:goalDimension`, uniqIf(UserID, (UserID != 0) AND (`_uniq_Goals` = 1)) FROM test.visits ARRAY JOIN Goals AS goals_alias, arrayEnumerateUniq(Goals.ID) AS `_uniq_Goals` WHERE (CounterID = 842440) GROUP BY `ym:s:goalDimension` WITH TOTALS ORDER BY `ym:s:goalDimension` LIMIT 0, 1 FORMAT JSONCompact;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:23.094223 [ 2880 ] {74ec0642-fcb6-4b60-a73d-fc31db422d4b} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:23.989591 [ 4018 ] {5b2af600-ef09-4e6f-9763-59030f88d67a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46036) (comment: 00040_aggregating_materialized_view.sql) (in query: CREATE MATERIALIZED VIEW test.basic_00040 ENGINE = AggregatingMergeTree(StartDate, (CounterID, StartDate), 8192) POPULATE AS SELECT CounterID, StartDate, sumState(Sign) AS Visits, uniqState(UserID) AS Users FROM test.visits GROUP BY CounterID, StartDate;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x0000000038567f8a 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x0000000038589080 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038585891 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 @ 0x00000000382f6666 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 2025.09.09 14:27:23.991458 [ 4018 ] {5b2af600-ef09-4e6f-9763-59030f88d67a} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x0000000038567f8a 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x0000000038589080 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038585891 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 @ 0x00000000382f6666 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 2025.09.09 14:27:24.426858 [ 2879 ] {e764a719-0394-4db6-a656-59c9d9c968cc} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46186) (comment: 00061_storage_buffer.sql) (in query: DROP TABLE IF EXISTS test.hits_buffer;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:24.428017 [ 2879 ] {e764a719-0394-4db6-a656-59c9d9c968cc} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:24.938042 [ 4018 ] {75edb108-91ac-4df3-b4b3-d681bbc8710f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46214) (comment: 00047_bar.sql) (in query: SELECT CounterID, count() AS c, bar(c, 0, 523264) FROM test.hits GROUP BY CounterID ORDER BY c DESC, CounterID ASC LIMIT 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:24.940070 [ 4018 ] {75edb108-91ac-4df3-b4b3-d681bbc8710f} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:25.217635 [ 4134 ] {5cb221c3-304a-4f7f-9263-84cac00f61a8} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONColumns format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 25000 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46146) (comment: 02293_formats_json_columns.sh) (in query: select * from file(data_02293, JSONColumns) 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000003830ebc4 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038314647 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038316280 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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&) @ 0x000000002fe3e879 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe37635 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe42726 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 15. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 2025.09.09 14:27:25.219354 [ 4134 ] {5cb221c3-304a-4f7f-9263-84cac00f61a8} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONColumns format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 25000 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000003830ebc4 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038314647 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038316280 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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&) @ 0x000000002fe3e879 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe37635 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe42726 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 15. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 2025.09.09 14:27:25.667806 [ 4018 ] {34da317f-f569-454d-ae7a-cb8a8f270aa7} 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.10505.altinitytest (altinity build)) (from [::1]:46228) (comment: 00172_hits_joins.gen.sql) (in query: SELECT EventDate, count() AS hits, any(visits) FROM test.hits ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate GROUP BY EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:25.670818 [ 4018 ] {34da317f-f569-454d-ae7a-cb8a8f270aa7} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:26.535846 [ 4042 ] {38be1044-7e12-486e-9882-0b17cb3deb1e} 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=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000003476a998 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034dea71f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddd295 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d88585 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&) @ 0x0000000034d5da37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:26.541321 [ 4042 ] {38be1044-7e12-486e-9882-0b17cb3deb1e} 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.10505.altinitytest (altinity build)) (from [::1]:46090) (comment: 00172_hits_joins.gen.sql) (in query: SELECT a.*, b.* FROM ( SELECT number AS k FROM system.numbers LIMIT 10 ) AS a ANY INNER JOIN ( SELECT number * 2 AS k, number AS joined FROM system.numbers LIMIT 10 ) AS b USING k ORDER BY joined SETTINGS any_join_distinct_right_table_keys = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000003476a998 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034dea71f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddd295 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d88585 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&) @ 0x0000000034d5da37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:27:26.668231 [ 4042 ] {38be1044-7e12-486e-9882-0b17cb3deb1e} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000003476a998 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034dea71f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034ddd295 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d88585 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&) @ 0x0000000034d5da37 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:27:27.171875 [ 2880 ] {c4724bd1-3841-442e-8301-40e4674c004e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=715). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46170) (comment: 01244_optimize_distributed_group_by_sharding_key.sql) (in query: select count(), * from dist_01247 group by number 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:27.173900 [ 2880 ] {c4724bd1-3841-442e-8301-40e4674c004e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=715). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:27.572425 [ 4082 ] {4438fcf3-9fdc-4a9f-b46d-68f29456189c} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactColumns format file. Error: Code: 92. DB::Exception: Cannot read rows from the data. (EMPTY_DATA_PASSED) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58856) (comment: 02293_formats_json_columns.sh) (in query: desc file(data_02293, JSONCompactColumns)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:27:27.573967 [ 4082 ] {4438fcf3-9fdc-4a9f-b46d-68f29456189c} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactColumns format file. Error: Code: 92. DB::Exception: Cannot read rows from the data. (EMPTY_DATA_PASSED) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:27:28.203321 [ 4134 ] {7e716a84-0136-4a45-8e5d-b63be34c9e6c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45294) (comment: 01244_optimize_distributed_group_by_sharding_key.sql) (in query: DROP DATABASE IF EXISTS test_9ba7q57o ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:28.296436 [ 4134 ] {7e716a84-0136-4a45-8e5d-b63be34c9e6c} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:28.486583 [ 2880 ] {817b0df6-b3f7-41a8-8e36-4d9272038b2c} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactColumns format file. Error: Code: 92. DB::Exception: Cannot read rows from the data. (EMPTY_DATA_PASSED) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58948) (comment: 02293_formats_json_columns.sh) (in query: select * from file(data_02293, JSONCompactColumns) order by c1, c2, c3), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000003830ebc4 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038314647 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038316280 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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&) @ 0x000000002fe3e879 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe37635 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe42726 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 15. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 2025.09.09 14:27:28.487950 [ 2880 ] {817b0df6-b3f7-41a8-8e36-4d9272038b2c} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactColumns format file. Error: Code: 92. DB::Exception: Cannot read rows from the data. (EMPTY_DATA_PASSED) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000003830ebc4 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038314647 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038316280 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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&) @ 0x000000002fe3e879 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002fe37635 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe42726 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 15. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 2025.09.09 14:27:28.779531 [ 4042 ] {b95fe135-cbbe-4db5-9dbf-09a09bc16ea9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=716). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58938) (comment: 00156_max_execution_speed_sample_merge.sql) (in query: SELECT count() FROM test.hits SAMPLE 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:28.781311 [ 4042 ] {b95fe135-cbbe-4db5-9dbf-09a09bc16ea9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=716). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:29.608901 [ 4621 ] {dfcb45fd-5812-411e-ae1d-5502562ce181} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45386) (comment: 03261_variant_permutation_bug.sql) (in query: DROP DATABASE IF EXISTS test_20nealmq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:29.610302 [ 4621 ] {dfcb45fd-5812-411e-ae1d-5502562ce181} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:29.702900 [ 4082 ] {2d059d87-e880-4480-81c2-e1af00341501} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45392) (comment: 03261_variant_permutation_bug.sql) (in query: DROP DATABASE IF EXISTS test_20nealmq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:29.704488 [ 4082 ] {2d059d87-e880-4480-81c2-e1af00341501} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:29.994028 [ 2880 ] {d20a8117-6615-45a4-bbd2-67a65003f260} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0): While executing WaitForAsyncInsert. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59050) (comment: 02193_async_insert_tcp_client_2.sh) (in query: INSERT INTO t_async_insert_02193_2 SETTINGS async_insert = 1 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::scheduleDataProcessingJob(DB::AsynchronousInsertQueue::InsertQuery const&, std::unique_ptr>, std::shared_ptr, unsigned long) @ 0x0000000033637536 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::AsynchronousInsertQueue::processBatchDeadlines(unsigned long) @ 0x000000003364d67c 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, unsigned long, bool)::$_0>(DB::AsynchronousInsertQueue::AsynchronousInsertQueue(std::shared_ptr, unsigned long, bool)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003365ebeb 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 11. ? @ 0x00007f550c19fac3 12. ? @ 0x00007f550c231850 2025.09.09 14:27:29.995073 [ 2880 ] {d20a8117-6615-45a4-bbd2-67a65003f260} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0): While executing WaitForAsyncInsert. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::scheduleDataProcessingJob(DB::AsynchronousInsertQueue::InsertQuery const&, std::unique_ptr>, std::shared_ptr, unsigned long) @ 0x0000000033637536 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::AsynchronousInsertQueue::processBatchDeadlines(unsigned long) @ 0x000000003364d67c 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, unsigned long, bool)::$_0>(DB::AsynchronousInsertQueue::AsynchronousInsertQueue(std::shared_ptr, unsigned long, bool)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003365ebeb 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 11. ? @ 0x00007f550c19fac3 12. ? @ 0x00007f550c231850 2025.09.09 14:27:30.635467 [ 2879 ] {b58d0c34-4154-448e-8074-5326c060c2cb} executeQuery: Code: 57. DB::Exception: Table test_3kd2yrk4.distinct_in_order already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00174_distinct_in_order.sql) (in query: /* ddl_entry=query-0000000005 */ CREATE TABLE test_3kd2yrk4.distinct_in_order UUID '192f1da6-8ecc-48ff-92f9-79e11c7cca8d' (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) 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 = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 174684851, compact_parts_max_granules_to_buffer = 116, compact_parts_merge_max_bytes_to_prefetch_part = 15952615, merge_max_block_size = 6401, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2478204604, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 33875, primary_key_compress_block_size = 44349), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:30.643422 [ 2879 ] {b58d0c34-4154-448e-8074-5326c060c2cb} executeQuery: Code: 57. DB::Exception: Table test_3kd2yrk4.distinct_in_order already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58956) (comment: 00174_distinct_in_order.sql) (in query: CREATE TABLE distinct_in_order (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) 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 = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 174684851, compact_parts_max_granules_to_buffer = 116, compact_parts_merge_max_bytes_to_prefetch_part = 15952615, merge_max_block_size = 6401, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2478204604, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 33875, primary_key_compress_block_size = 44349), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:30.645449 [ 2879 ] {b58d0c34-4154-448e-8074-5326c060c2cb} TCPHandler: Code: 57. DB::Exception: Table test_3kd2yrk4.distinct_in_order 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:31.651663 [ 4727 ] {6853164a-ecdc-4e28-aa52-064114c3c4ca} 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.10505.altinitytest (altinity build)) (from [::1]:59078) (comment: 00145_aggregate_functions_statistics.sql) (in query: SELECT covarSamp(ResolutionWidth, ResolutionHeight) FROM (SELECT ResolutionWidth, ResolutionHeight FROM test.hits 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:31.653308 [ 4727 ] {6853164a-ecdc-4e28-aa52-064114c3c4ca} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:32.004348 [ 4300 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x0000000033981379 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:132: DB::DDLWorker::startup() @ 0x0000000033930b5d 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: void std::__function::__policy_invoker const&)>::__call_impl, std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000032a9509f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000020712266 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020713c80 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:32.682867 [ 2880 ] {2b502483-fb0f-422b-9d21-e8291f9e297e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=717). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59230) (comment: 00145_aggregate_functions_statistics.sql) (in query: SELECT stddevSamp(ResolutionWidth) FROM (SELECT ResolutionWidth FROM test.hits 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:32.684617 [ 2880 ] {2b502483-fb0f-422b-9d21-e8291f9e297e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=717). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:33.006072 [ 4312 ] {} DDLWorker(test_c8xi93jt): Error on initialization of test_c8xi93jt: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_c8xi93jt' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x0000000033981379 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:132: DB::DDLWorker::startup() @ 0x0000000033930b5d 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: void std::__function::__policy_invoker const&)>::__call_impl, std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000032a9509f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000020712266 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020713c80 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10505.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020707bdb 5. ./src/Common/AsyncLoader.h:547: DB::DatabaseReplicated::waitDatabaseStarted() const @ 0x0000000032a297f7 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1054: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000032a4e040 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000032abcc4c 8. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000032ab5030 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x0000000033931c73 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000339819a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003398175f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:33.382878 [ 2879 ] {65ba3561-facf-45df-bad1-1872747cee7a} executeQuery: Code: 117. DB::Exception: Unknown column found in input data: b: (in file/uri /var/lib/clickhouse/user_files/data_02293): While executing JSONColumnsBlockInputFormatBase: While executing File. (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59198) (comment: 02293_formats_json_columns.sh) (in query: select * from file(data_02293, JSONColumns, 'a UInt32, t String') order by a, t 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Processors/Formats/Impl/JSONColumnsBlockInputFormatBase.cpp:167: DB::JSONColumnsBlockInputFormatBase::read() @ 0x000000003b240cb8 5. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aed3839 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aec05d2 12. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x0000000038323057 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:27:33.386387 [ 2879 ] {65ba3561-facf-45df-bad1-1872747cee7a} TCPHandler: Code: 117. DB::Exception: Unknown column found in input data: b: (in file/uri /var/lib/clickhouse/user_files/data_02293): While executing JSONColumnsBlockInputFormatBase: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Processors/Formats/Impl/JSONColumnsBlockInputFormatBase.cpp:167: DB::JSONColumnsBlockInputFormatBase::read() @ 0x000000003b240cb8 5. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aed3839 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aec05d2 12. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x0000000038323057 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:27:33.465644 [ 4082 ] {d8e4ffed-b589-4735-a1e2-e8f2cccb7c4b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59364) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:33.468334 [ 4082 ] {d8e4ffed-b589-4735-a1e2-e8f2cccb7c4b} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:35.078871 [ 4621 ] {951a3456-3f72-49ed-b377-98b4b589372e} executeQuery: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59276) (comment: 00152_insert_different_granularity.sql) (in query: -- We have removed testing of OPTIMIZE because it's too heavy on very slow builds (debug + coverage + thread fuzzer with sleeps) -- OPTIMIZE TABLE fixed_granularity_table FINAL; -- and even after optimize DETACH TABLE fixed_granularity_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a48493 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a48ff9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492f009 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:35.079801 [ 4727 ] {f203f49f-46ac-4bb7-9b17-f6c054af09e6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=716). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59376) (comment: 00148_monotonic_functions_and_index.sql) (in query: SELECT count() FROM test.hits WHERE CounterID <= 732797 AND CounterID > 107931;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:35.080514 [ 4621 ] {951a3456-3f72-49ed-b377-98b4b589372e} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a48493 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a48ff9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492f009 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:35.109981 [ 4727 ] {f203f49f-46ac-4bb7-9b17-f6c054af09e6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=716). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:35.214412 [ 4082 ] {4fc0b399-1539-4241-a11e-b3d263987136} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45660) (comment: 00152_insert_different_granularity.sql) (in query: DROP DATABASE IF EXISTS test_6y9va1v5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:35.215651 [ 4082 ] {4fc0b399-1539-4241-a11e-b3d263987136} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:35.226412 [ 2879 ] {fe7b3cd8-7b65-434e-aa90-f51bd4e0e873} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45666) (comment: 00152_insert_different_granularity.sql) (in query: DROP DATABASE IF EXISTS test_6y9va1v5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:35.227644 [ 2879 ] {fe7b3cd8-7b65-434e-aa90-f51bd4e0e873} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:35.254823 [ 4041 ] {9dae53e5-a2a4-448b-83c9-241b8af180df} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=713). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59458) (comment: 00060_move_to_prewhere_and_sets.sql) (in query: SELECT uniq(URL) FROM test.hits WHERE TraficSourceID IN (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:35.256859 [ 4041 ] {9dae53e5-a2a4-448b-83c9-241b8af180df} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=713). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:35.302156 [ 4134 ] {6a8da4e9-fd92-40ae-ba63-74dda0ac9c69} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45672) (comment: 00152_insert_different_granularity.sql) (in query: DROP DATABASE IF EXISTS test_6y9va1v5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:35.303264 [ 4134 ] {6a8da4e9-fd92-40ae-ba63-74dda0ac9c69} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:35.616466 [ 4727 ] {a3f97c04-26e8-48db-a4ca-f18a9afb4ae8} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00161_parallel_parsing_with_names.sh) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_11.parsing_with_names UUID '428e44fd-ee58-4b63-ab47-ca9719b8980b' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:35.620921 [ 4727 ] {a3f97c04-26e8-48db-a4ca-f18a9afb4ae8} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59486) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:35.622344 [ 4727 ] {a3f97c04-26e8-48db-a4ca-f18a9afb4ae8} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:36.099483 [ 4041 ] {e9ab20f5-36b0-428d-8983-5df9d86e72ef} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59502) (comment: 01270_optimize_skip_unused_shards_low_cardinality.sql) (in query: drop table data_01270;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:36.100952 [ 4041 ] {e9ab20f5-36b0-428d-8983-5df9d86e72ef} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:36.766665 [ 4727 ] {7318628e-b1c3-4414-ac9b-2be38fb5911a} executeQuery: Code: 57. DB::Exception: Table test.hits_dst already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59522) (comment: 00061_storage_buffer.sql) (in query: CREATE TABLE test.hits_dst AS test.hits ENGINE = MergeTree PARTITION BY toYYYYMM(EventDate) ORDER BY (CounterID, EventDate, intHash32(UserID)) SAMPLE BY intHash32(UserID) SETTINGS storage_policy = 'default', index_granularity = 28160, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 9, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 198506423, compact_parts_max_granules_to_buffer = 237, compact_parts_merge_max_bytes_to_prefetch_part = 966242, merge_max_block_size = 7847, old_parts_lifetime = 480., 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 = 9478234811, index_granularity_bytes = 14848223, concurrent_part_removal_threshold = 45, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 31424, primary_key_compress_block_size = 14023), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:36.769747 [ 4727 ] {7318628e-b1c3-4414-ac9b-2be38fb5911a} TCPHandler: Code: 57. DB::Exception: Table test.hits_dst 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:37.821015 [ 4621 ] {a499b6d8-d116-4be6-9311-a7f50186ec21} 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.10505.altinitytest (altinity build)) (from [::1]:40194) (comment: 00140_rename.sql) (in query: SELECT sum(Sign) FROM test.hits WHERE CounterID = 912887;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:37.822215 [ 4042 ] {54fa225f-07ee-489d-8a7b-39cc9f88faea} executeQuery: Code: 57. DB::Exception: Table test_15.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40198) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:37.823377 [ 4621 ] {a499b6d8-d116-4be6-9311-a7f50186ec21} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:37.823666 [ 4042 ] {54fa225f-07ee-489d-8a7b-39cc9f88faea} TCPHandler: Code: 57. DB::Exception: Table test_15.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:38.116497 [ 4134 ] {42d613c2-9db0-42d7-a0e8-f67025ca271c} executeQuery: Code: 117. DB::Exception: Input data has too many columns, expected 2 columns: (in file/uri /var/lib/clickhouse/user_files/data_02293): While executing JSONColumnsBlockInputFormatBase: While executing File. (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59592) (comment: 02293_formats_json_columns.sh) (in query: select * from file(data_02293, JSONCompactColumns, 'a UInt32, t UInt32') order by a, t), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90680a 4. ./build_docker/./src/Processors/Formats/Impl/JSONColumnsBlockInputFormatBase.cpp:176: DB::JSONColumnsBlockInputFormatBase::read() @ 0x000000003b2409d9 5. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aed3839 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aec05d2 12. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x0000000038323057 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:27:38.119442 [ 4134 ] {42d613c2-9db0-42d7-a0e8-f67025ca271c} TCPHandler: Code: 117. DB::Exception: Input data has too many columns, expected 2 columns: (in file/uri /var/lib/clickhouse/user_files/data_02293): While executing JSONColumnsBlockInputFormatBase: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000d90680a 4. ./build_docker/./src/Processors/Formats/Impl/JSONColumnsBlockInputFormatBase.cpp:176: DB::JSONColumnsBlockInputFormatBase::read() @ 0x000000003b2409d9 5. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aed3839 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aec05d2 12. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x0000000038323057 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:27:38.904007 [ 2880 ] {df96a886-dbae-4c88-a5f5-3f19f2495e62} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONColumns format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 3 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40266) (comment: 02293_formats_json_columns.sh) (in query: desc file(data_02293, JSONColumns) settings input_format_max_rows_to_read_for_schema_inference=3, input_format_json_infer_incomplete_types_as_strings=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:27:38.905813 [ 2880 ] {df96a886-dbae-4c88-a5f5-3f19f2495e62} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONColumns format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 3 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/data_02293). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:27:38.937198 [ 4082 ] {668fd0ad-f106-4714-86e1-9159e89d0781} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=716). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40264) (comment: 00159_parallel_formatting_json_and_friends_2.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a, MobilePhoneModel as b, ClientIP6 as c FROM test.hits ORDER BY a, b, c LIMIT 3000000 Format JSONCompactEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:38.939012 [ 4082 ] {668fd0ad-f106-4714-86e1-9159e89d0781} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=716). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:39.112283 [ 4730 ] {72f732dd-5659-4fa4-9cd7-7bbd9c141266} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00161_parallel_parsing_with_names.sh) (in query: /* ddl_entry=query-0000000006 */ CREATE TABLE test_11.parsing_with_names UUID '64545ee8-355d-4b55-ad79-025bf193ffb0' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:39.116706 [ 4730 ] {72f732dd-5659-4fa4-9cd7-7bbd9c141266} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40268) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:39.118329 [ 4730 ] {72f732dd-5659-4fa4-9cd7-7bbd9c141266} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:39.154650 [ 4018 ] {9be54fda-dea9-4d2b-9c4e-b7cfbd144eb1} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_c8xi93jt' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x0000000033981379 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:132: DB::DDLWorker::startup() @ 0x0000000033930b5d 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: void std::__function::__policy_invoker const&)>::__call_impl, std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000032a9509f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000020712266 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020713c80 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10505.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45462) (comment: 02251_last_day_of_month.sql) (in query: CREATE DATABASE IF NOT EXISTS test_c8xi93jt ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020707bdb 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065b79b 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a668 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:27:39.156238 [ 4018 ] {9be54fda-dea9-4d2b-9c4e-b7cfbd144eb1} DynamicQueryHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_c8xi93jt' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x0000000033981379 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:132: DB::DDLWorker::startup() @ 0x0000000033930b5d 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: void std::__function::__policy_invoker const&)>::__call_impl, std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000032a9509f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000020712266 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020713c80 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10505.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020707bdb 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065b79b 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a668 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:39.815388 [ 4727 ] {d5d617f0-076a-4232-8eb6-e9673ea82bc4} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40206) (comment: 00044_any_left_join_string.sql) (in query: SELECT domain, hits, visits FROM ( SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain ) ANY LEFT JOIN ( SELECT domain(StartURL) AS domain, sum(Sign) AS visits FROM test.visits GROUP BY domain ) USING domain ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ea4dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:27:39.817264 [ 4727 ] {d5d617f0-076a-4232-8eb6-e9673ea82bc4} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ea4dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:27:39.874159 [ 4042 ] {f3e350eb-65ff-4564-a6e3-e00785216e65} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40254) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format CSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:39.874181 [ 4621 ] {35dfa1fc-dddd-4252-8b67-81ff3a6bdecf} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'GoalsReached' in scope SELECT GoalsReached AS k, count() AS c FROM test.hits GROUP BY k ORDER BY c DESC LIMIT 10. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40262) (comment: 00078_group_by_arrays.sql) (in query: SELECT GoalsReached AS k, count() AS c FROM test.hits GROUP BY k ORDER BY c DESC LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:39.874181 [ 4134 ] {0282e7a7-e5eb-4d5b-b8bc-d3b375487d5d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40294) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format CSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:39.875798 [ 4042 ] {f3e350eb-65ff-4564-a6e3-e00785216e65} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:39.875820 [ 4621 ] {35dfa1fc-dddd-4252-8b67-81ff3a6bdecf} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'GoalsReached' in scope SELECT GoalsReached AS k, count() AS c FROM test.hits GROUP BY k ORDER BY c DESC LIMIT 10. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:39.875825 [ 4134 ] {0282e7a7-e5eb-4d5b-b8bc-d3b375487d5d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:40.086082 [ 4018 ] {7cc63785-1d90-4ab1-abca-e52a36c76421} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:d9cb765f-ded3-4ea9-94e9-c67489147147'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49710) (comment: 02676_distinct_reading_in_order_analyzer.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zc2oikup ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.087661 [ 4018 ] {7cc63785-1d90-4ab1-abca-e52a36c76421} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:d9cb765f-ded3-4ea9-94e9-c67489147147'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.104348 [ 4621 ] {9c55f046-3527-4cea-9317-13f14ab6b052} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:ae0a03a9-07be-4f62-b9de-7cce808b4e72'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49734) (comment: 02004_intersect_except_distinct_operators.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ijl5p3ip ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.105850 [ 4621 ] {9c55f046-3527-4cea-9317-13f14ab6b052} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:ae0a03a9-07be-4f62-b9de-7cce808b4e72'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.121682 [ 4621 ] {c5e9a034-e15b-4274-ae81-81ed16c1375f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:6e1f3c0c-1c1c-48cf-a2d2-7b0ae841f290'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49772) (comment: 03130_convert_outer_join_to_inner_join.sql) (in query: CREATE DATABASE IF NOT EXISTS test_7lcwskpb ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.123126 [ 4621 ] {c5e9a034-e15b-4274-ae81-81ed16c1375f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:6e1f3c0c-1c1c-48cf-a2d2-7b0ae841f290'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.139760 [ 2879 ] {b12f9598-d012-450b-8340-108f0c8729e0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:7dc4a9fa-46f6-4d74-ac47-93c86c7d8eb7'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49786) (comment: 01355_ilike.sql) (in query: CREATE DATABASE IF NOT EXISTS test_imlrqkhn ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.141318 [ 2879 ] {b12f9598-d012-450b-8340-108f0c8729e0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:7dc4a9fa-46f6-4d74-ac47-93c86c7d8eb7'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.158987 [ 2879 ] {9ab482f2-08ee-4827-8549-636b6af36c52} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:bdfa0578-b3b6-4efd-9110-71904bf15340'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49798) (comment: 00394_new_nested_column_keeps_offsets.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0nghcl6x ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.160352 [ 2879 ] {9ab482f2-08ee-4827-8549-636b6af36c52} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:bdfa0578-b3b6-4efd-9110-71904bf15340'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.177875 [ 2879 ] {0712f160-39b5-43d1-b55f-c1c41191d66d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:25edf013-8eaa-47c8-a5a3-3f7a43c45f07'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49816) (comment: 02155_csv_with_strings_with_slash.sh) (in query: CREATE DATABASE IF NOT EXISTS test_1a31qdqy ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.179485 [ 2879 ] {0712f160-39b5-43d1-b55f-c1c41191d66d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:25edf013-8eaa-47c8-a5a3-3f7a43c45f07'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.275251 [ 2879 ] {e3e80c5a-d079-4f14-81a9-6625995e86cf} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:957d4d70-6459-44c9-83a2-20e4cebe9a0e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49826) (comment: 02771_multiple_query_arguments.sh) (in query: CREATE DATABASE IF NOT EXISTS test_a4w9afcy ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.276665 [ 2879 ] {e3e80c5a-d079-4f14-81a9-6625995e86cf} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:957d4d70-6459-44c9-83a2-20e4cebe9a0e'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.290832 [ 4042 ] {5f85a058-2721-42dd-9533-7dfc879ee6d0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:f666bd1a-d23d-47fd-afef-b9bcd7a4c2f8'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49840) (comment: 02240_filesystem_query_cache.sql) (in query: CREATE DATABASE IF NOT EXISTS test_fwabauoo ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.292252 [ 4042 ] {5f85a058-2721-42dd-9533-7dfc879ee6d0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:f666bd1a-d23d-47fd-afef-b9bcd7a4c2f8'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.307005 [ 4042 ] {29cfbd11-1d2f-486f-b141-c9835d33827d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:e0b11098-4eb2-4517-b643-4c23709cff72'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49848) (comment: 01105_string_like.sql) (in query: CREATE DATABASE IF NOT EXISTS test_fgiys65z ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.308379 [ 4042 ] {29cfbd11-1d2f-486f-b141-c9835d33827d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:e0b11098-4eb2-4517-b643-4c23709cff72'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.323996 [ 4042 ] {4bda180b-5402-4ae1-a548-c5f89d27ceab} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:0dd5d103-c952-47d7-b65b-6053f97e3666'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49856) (comment: 02385_analyzer_aliases_compound_expression.sql) (in query: CREATE DATABASE IF NOT EXISTS test_467cz769 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.325561 [ 4042 ] {4bda180b-5402-4ae1-a548-c5f89d27ceab} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:0dd5d103-c952-47d7-b65b-6053f97e3666'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.395254 [ 4042 ] {69db8b83-544e-472e-aad7-8c6004e29873} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:736927e7-4b73-457e-9e99-7181417decba'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49858) (comment: 00002_log_and_exception_messages_formatting.sql) (in query: CREATE DATABASE IF NOT EXISTS test_idduz7x0 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.396943 [ 4042 ] {69db8b83-544e-472e-aad7-8c6004e29873} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:736927e7-4b73-457e-9e99-7181417decba'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.412100 [ 4042 ] {38a43907-b514-4dbf-8ff0-1cc0c38e745d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:76716217-bb0d-4742-ad0d-21b7258537dd'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49864) (comment: 02504_regexp_dictionary_table_source.sql) (in query: CREATE DATABASE IF NOT EXISTS test_7yt91ugj ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.413608 [ 4042 ] {38a43907-b514-4dbf-8ff0-1cc0c38e745d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:76716217-bb0d-4742-ad0d-21b7258537dd'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.428252 [ 4042 ] {63e5641a-4d32-43e4-9a83-09ebba41cf12} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:2f65c556-21fd-49ba-9b54-fd7ec140c1b8'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49878) (comment: 00578_merge_table_sampling.sql) (in query: CREATE DATABASE IF NOT EXISTS test_17r44uij ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.429768 [ 4042 ] {63e5641a-4d32-43e4-9a83-09ebba41cf12} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:2f65c556-21fd-49ba-9b54-fd7ec140c1b8'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.444571 [ 4042 ] {cb74f057-8b9d-42bc-9b8c-ccf19d1ba16a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:ad21df4f-9bb0-4d46-8990-596e7459d0e4'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49886) (comment: 03224_json_merges_new_type_in_shared_data.sql) (in query: CREATE DATABASE IF NOT EXISTS test_xhihfgv9 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.446160 [ 4042 ] {cb74f057-8b9d-42bc-9b8c-ccf19d1ba16a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:ad21df4f-9bb0-4d46-8990-596e7459d0e4'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.461398 [ 2879 ] {7eb8f548-d928-47cb-bc75-b3f0184555a3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:35c3721d-865a-49f7-8038-4c809e96ec61'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49892) (comment: 01003_kill_query_race_condition.sh) (in query: CREATE DATABASE IF NOT EXISTS test_q8x87qgl ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.462884 [ 2879 ] {7eb8f548-d928-47cb-bc75-b3f0184555a3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:35c3721d-865a-49f7-8038-4c809e96ec61'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.554280 [ 4621 ] {d9f12851-a563-4493-a51d-561059e4f153} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:f5eebc9d-f5aa-4efd-8dfc-a05ef49140b0'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49906) (comment: 01042_system_reload_dictionary_reloads_completely.sh) (in query: CREATE DATABASE IF NOT EXISTS test_n66l2fwj ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.559650 [ 4621 ] {d9f12851-a563-4493-a51d-561059e4f153} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:f5eebc9d-f5aa-4efd-8dfc-a05ef49140b0'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.634314 [ 4621 ] {76029861-b0c8-45d7-9ea7-755aac4afe7b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:86252e88-f54a-4db6-8556-f36faa04d660'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49922) (comment: 00953_indices_alter_exceptions.sh) (in query: CREATE DATABASE IF NOT EXISTS test_4fj9vrfp ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.635891 [ 4621 ] {76029861-b0c8-45d7-9ea7-755aac4afe7b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:86252e88-f54a-4db6-8556-f36faa04d660'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.651919 [ 4621 ] {e4a9c7d2-a78b-4ed3-8b75-7356f604006a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:e3629568-a804-49d9-87a3-2e404b025490'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49934) (comment: 02963_test_flexible_disk_configuration.sql) (in query: CREATE DATABASE IF NOT EXISTS test_flzgiht4 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.653619 [ 4621 ] {e4a9c7d2-a78b-4ed3-8b75-7356f604006a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:e3629568-a804-49d9-87a3-2e404b025490'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.668174 [ 4730 ] {f08ee956-3726-4b4d-970e-34d12020276e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:62f5532a-e2dc-4caa-9227-7620f862624d'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49936) (comment: 01635_nullable_fuzz.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1pei5s2k ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:40.669807 [ 4730 ] {f08ee956-3726-4b4d-970e-34d12020276e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '9cd04cf8cbd3:9000:859249d0-8a49-4b2a-a782-a1699864fc08', current host ID: '9cd04cf8cbd3:9000:62f5532a-e2dc-4caa-9227-7620f862624d'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:27:40.889033 [ 4018 ] {778d9a29-e88d-48c8-8cac-a875b0d676b4} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40348) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format TSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:40.891020 [ 4018 ] {778d9a29-e88d-48c8-8cac-a875b0d676b4} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:42.207299 [ 2880 ] {5a0a0826-b317-4617-abbf-bd395bd234c2} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'PredLastVisit' in scope SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40316) (comment: 00020_distinct_order_by_distributed.sql) (in query: SELECT count() FROM (SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:42.209329 [ 2880 ] {5a0a0826-b317-4617-abbf-bd395bd234c2} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'PredLastVisit' in scope SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID ASC. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:42.444553 [ 2879 ] {598ebeb4-a611-4fcb-9821-4ba502d53bf4} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00161_parallel_parsing_with_names.sh) (in query: /* ddl_entry=query-0000000008 */ CREATE TABLE test_11.parsing_with_names UUID '5e01ceb8-f279-42be-b4d7-09a91a79b3f9' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:42.450092 [ 2879 ] {598ebeb4-a611-4fcb-9821-4ba502d53bf4} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40412) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:42.451823 [ 2879 ] {598ebeb4-a611-4fcb-9821-4ba502d53bf4} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:42.799765 [ 4621 ] {e61f48ba-3d6d-4961-8771-04b1bf82a0e0} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40328) (comment: 00165_jit_aggregate_functions.sql) (in query: SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:42.801530 [ 4621 ] {e61f48ba-3d6d-4961-8771-04b1bf82a0e0} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. Maybe you meant: ['WatchIDs']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:43.193766 [ 4042 ] {14d1bd3a-06c9-4e64-b996-6d2d268544e8} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Title' in scope SELECT sumDistinct(sipHash64(decodeXMLComponent(Title) AS decoded)) FROM test.hits WHERE Title != decoded. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40368) (comment: 00160_decode_xml_component.sql) (in query: SELECT sum(DISTINCT sipHash64(decodeXMLComponent(Title) AS decoded)) FROM test.hits WHERE Title != decoded;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:27:43.195635 [ 4042 ] {14d1bd3a-06c9-4e64-b996-6d2d268544e8} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Title' in scope SELECT sumDistinct(sipHash64(decodeXMLComponent(Title) AS decoded)) FROM test.hits WHERE Title != decoded. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:27:43.254940 [ 2880 ] {c304cb48-61a2-4de4-892b-30c0cec523b5} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40432) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format CSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:43.256526 [ 2880 ] {c304cb48-61a2-4de4-892b-30c0cec523b5} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:43.323347 [ 4730 ] {ab72083a-f4eb-4e36-86d5-f0778ab9715e} executeQuery: Code: 57. DB::Exception: Table test_sc1bfgcv.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40440) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:43.325097 [ 4730 ] {ab72083a-f4eb-4e36-86d5-f0778ab9715e} TCPHandler: Code: 57. DB::Exception: Table test_sc1bfgcv.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:44.163978 [ 4018 ] {96acd849-1aed-4bf0-b554-8b181077a446} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40508) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format TSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:44.166099 [ 4018 ] {96acd849-1aed-4bf0-b554-8b181077a446} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:44.894151 [ 4134 ] {2c52692b-79e7-4a33-a4d5-62718e8c57b2} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT count() FROM test.hits WHERE NOT ((EventDate >= toDate('2015-01-01')) AND (EventDate < toDate('2015-02-01'))). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40456) (comment: 00055_index_and_not.sql) (in query: SELECT count() FROM test.hits WHERE NOT (EventDate >= toDate('2015-01-01') AND EventDate < toDate('2015-02-01')) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342ebdc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 2025.09.09 14:27:44.896204 [ 4134 ] {2c52692b-79e7-4a33-a4d5-62718e8c57b2} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT count() FROM test.hits WHERE NOT ((EventDate >= toDate('2015-01-01')) AND (EventDate < toDate('2015-02-01'))). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342ebdc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 2025.09.09 14:27:45.981885 [ 4082 ] {76e90171-2e66-4f3b-a281-c1b56b7c3176} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT count() FROM test.hits WHERE EventDate = '2014-03-18'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40538) (comment: 00072_compare_date_and_string_index.sql) (in query: SELECT count() FROM test.hits WHERE EventDate = '2014-03-18';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342ebdc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 26. ? @ 0x00007f550c19fac3 27. ? @ 0x00007f550c231850 2025.09.09 14:27:45.984143 [ 4082 ] {76e90171-2e66-4f3b-a281-c1b56b7c3176} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT count() FROM test.hits WHERE EventDate = '2014-03-18'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342ebdc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 26. ? @ 0x00007f550c19fac3 27. ? @ 0x00007f550c231850 2025.09.09 14:27:46.133766 [ 2879 ] {7b063c4f-636d-4890-a865-52fb60ba40b5} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT CAST(EventTime, 'DateTime(\'Asia/Dubai\')') FROM test.hits ORDER BY EventTime DESC LIMIT 10. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40632) (comment: 00011_sorting.sql) (in query: SELECT EventTime::DateTime('Asia/Dubai') FROM test.hits ORDER BY EventTime 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:46.135246 [ 2879 ] {7b063c4f-636d-4890-a865-52fb60ba40b5} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT CAST(EventTime, 'DateTime(\'Asia/Dubai\')') FROM test.hits ORDER BY EventTime DESC LIMIT 10. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:46.567916 [ 4018 ] {806b599a-6a37-48e8-bb0d-4554ca0b6905} executeQuery: Code: 57. DB::Exception: Table test_sc1bfgcv.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40648) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:46.567989 [ 2880 ] {6e740018-0174-40d7-8d1a-fd45b6ae74dd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=719): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40588) (comment: 03215_view_with_recursive.sql) (in query: SELECT * FROM 03215_test_v;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:128: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003c066e83 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x000000003c0663cd 9. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:46.569699 [ 4018 ] {806b599a-6a37-48e8-bb0d-4554ca0b6905} TCPHandler: Code: 57. DB::Exception: Table test_sc1bfgcv.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:46.618775 [ 2880 ] {6e740018-0174-40d7-8d1a-fd45b6ae74dd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=719): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:128: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003c066e83 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x000000003c0663cd 9. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:27:47.109902 [ 4727 ] {1553a1ed-d40a-46d9-9210-fa242936cd47} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.visits WHERE CounterID IN (942285, 577322). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50168) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:47.111596 [ 4727 ] {1553a1ed-d40a-46d9-9210-fa242936cd47} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.visits WHERE CounterID IN (942285, 577322). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:47.416730 [ 4727 ] {97aae74b-7147-4995-bc88-37dcfc0c1179} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50196) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format CSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:47.418389 [ 4727 ] {97aae74b-7147-4995-bc88-37dcfc0c1179} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:48.059654 [ 4018 ] {60ac6513-1e65-4d45-b779-5b512f9f4ca3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM test.hits WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY URL, EventDate, EventDate ORDER BY URL ASC, EventDate ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50234) (comment: 00069_duplicate_aggregation_keys.sql) (in query: SELECT URL, EventDate, max(URL) FROM test.hits WHERE CounterID = 1704509 AND UserID = 4322253409885123546 GROUP BY URL, EventDate, EventDate ORDER BY URL, EventDate;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:48.061218 [ 4018 ] {60ac6513-1e65-4d45-b779-5b512f9f4ca3} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM test.hits WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY URL, EventDate, EventDate ORDER BY URL ASC, EventDate ASC. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:49.768224 [ 2879 ] {dcbbb4df-0b47-4919-859a-901b0f8f96d3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, count() FROM remote('127.0.0.1', test.hits) WHERE UserID GLOBAL IN (SELECT UserID FROM test.hits) GROUP BY EventDate ORDER BY EventDate ASC LIMIT 5. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50346) (comment: 00088_global_in_one_shard_and_rows_before_limit.sql) (in query: SELECT EventDate, count() FROM remote('127.0.0.1', test.hits) WHERE UserID GLOBAL IN (SELECT UserID FROM test.hits) GROUP BY EventDate ORDER BY EventDate LIMIT 5 FORMAT JSONCompact;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:49.770185 [ 2879 ] {dcbbb4df-0b47-4919-859a-901b0f8f96d3} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, count() FROM remote('127.0.0.1', test.hits) WHERE UserID GLOBAL IN (SELECT UserID FROM test.hits) GROUP BY EventDate ORDER BY EventDate ASC LIMIT 5. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:50.133508 [ 4082 ] {93cfbf1d-adc5-4bfa-9728-f8bb33fedc5e} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'PageCharset' in scope 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. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50394) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:50.135381 [ 4082 ] {93cfbf1d-adc5-4bfa-9728-f8bb33fedc5e} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'PageCharset' in scope 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. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:50.717121 [ 4018 ] {3825abed-193f-4b90-a557-97e4e5d965bc} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50430) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format CSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:50.718776 [ 4018 ] {3825abed-193f-4b90-a557-97e4e5d965bc} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:50.860575 [ 4042 ] {c2229246-bd3f-4102-b85e-df072d0c373b} 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.10505.altinitytest (altinity build)) (from [::1]:50424) (comment: 00145_aggregate_functions_statistics.sql) (in query: SELECT round(varSamp(ResolutionWidth), 6) 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:50.862537 [ 4042 ] {c2229246-bd3f-4102-b85e-df072d0c373b} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:27:51.476695 [ 4134 ] {bab2e251-77a8-4450-a4c9-a4522740a2df} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'SendTiming' in scope 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. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50372) (comment: 00171_grouping_aggregated_transform_bug.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 max_block_size = 63169;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:27:51.478747 [ 4134 ] {bab2e251-77a8-4450-a4c9-a4522740a2df} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'SendTiming' in scope 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. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:27:51.560083 [ 4621 ] {418a7f71-bef2-4e66-bd2e-0a551322925d} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT UserID, CAST(EventTime, 'DateTime(\'Asia/Dubai\')'), pp.Key1, pp.Key2, ParsedParams.Key1 FROM test.hits ARRAY JOIN ParsedParams AS pp WHERE CounterID = 1704509 ORDER BY UserID ASC, EventTime ASC, pp.Key1 ASC, pp.Key2 ASC LIMIT 100. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50468) (comment: 00075_left_array_join.sql) (in query: SELECT UserID, EventTime::DateTime('Asia/Dubai'), pp.Key1, pp.Key2, ParsedParams.Key1 FROM test.hits ARRAY JOIN ParsedParams AS pp WHERE CounterID = 1704509 ORDER BY UserID, EventTime, pp.Key1, pp.Key2 LIMIT 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:51.562287 [ 4621 ] {418a7f71-bef2-4e66-bd2e-0a551322925d} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT UserID, CAST(EventTime, 'DateTime(\'Asia/Dubai\')'), pp.Key1, pp.Key2, ParsedParams.Key1 FROM test.hits ARRAY JOIN ParsedParams AS pp WHERE CounterID = 1704509 ORDER BY UserID ASC, EventTime ASC, pp.Key1 ASC, pp.Key2 ASC LIMIT 100. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:52.291866 [ 2879 ] {f03cdae9-8390-4fec-b84e-2b6abeb47d0a} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50436) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000034e6bbed 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000034e6e7da 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6c9ac 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6d5cd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589fa4d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 21. ? @ 0x00007f550c19fac3 22. ? @ 0x00007f550c231850 2025.09.09 14:27:52.294031 [ 2879 ] {f03cdae9-8390-4fec-b84e-2b6abeb47d0a} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000034e6bbed 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000034e6e7da 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6c9ac 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6d5cd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589fa4d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 21. ? @ 0x00007f550c19fac3 22. ? @ 0x00007f550c231850 2025.09.09 14:27:52.538852 [ 4082 ] {df086dd1-5937-4560-ad7b-fe967604c39f} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50516) (comment: 00165_jit_aggregate_functions.sql) (in query: SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:52.540739 [ 4082 ] {df086dd1-5937-4560-ad7b-fe967604c39f} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. Maybe you meant: ['WatchIDs']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:53.740627 [ 4041 ] {8c845003-3ef2-44a7-a74f-fedcf4b08107} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=717). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50600) (comment: 00063_loyalty_joins.sql) (in query: SELECT loyalty, count() FROM ( SELECT loyalty, UserID FROM ( SELECT UserID 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:53.745100 [ 4041 ] {8c845003-3ef2-44a7-a74f-fedcf4b08107} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=717). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:53.953189 [ 4134 ] {f556ee03-3ce2-446d-8052-a6a35edf8d9d} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT EventDate + (UserID % 365) AS EventDate, CounterID FROM test.hits WHERE CounterID = 1704509. Maybe you meant: ['EventDate']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50548) (comment: 00054_merge_tree_partitions.sql) (in query: INSERT INTO test.partitions SELECT EventDate + UserID % 365 AS EventDate, CounterID FROM test.hits WHERE CounterID = 1704509;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9fb23 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 27. ? @ 0x00007f550c19fac3 28. ? @ 0x00007f550c231850 2025.09.09 14:27:53.955042 [ 4134 ] {f556ee03-3ce2-446d-8052-a6a35edf8d9d} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT EventDate + (UserID % 365) AS EventDate, CounterID FROM test.hits WHERE CounterID = 1704509. Maybe you meant: ['EventDate']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9fb23 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 27. ? @ 0x00007f550c19fac3 28. ? @ 0x00007f550c231850 2025.09.09 14:27:54.163183 [ 4041 ] {763e0add-62f9-48f0-8682-2a9cab535fd8} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'StartDate' in scope SELECT any(0) FROM test.visits WHERE toInt32(toDateTime(StartDate)) > 1000000000. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50658) (comment: 00085_monotonic_evaluation_segfault.sql) (in query: SELECT any(0) FROM test.visits WHERE (toInt32(toDateTime(StartDate))) > 1000000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342ebdc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 2025.09.09 14:27:54.164718 [ 4041 ] {763e0add-62f9-48f0-8682-2a9cab535fd8} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'StartDate' in scope SELECT any(0) FROM test.visits WHERE toInt32(toDateTime(StartDate)) > 1000000000. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342ebdc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 2025.09.09 14:27:54.892880 [ 4134 ] {9e41339e-c776-439b-898e-4ce4cc2250b1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=716). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50696) (comment: 01532_tuple_with_name_type.sql) (in query: DESCRIBE TABLE test_01532_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:54.899747 [ 4134 ] {9e41339e-c776-439b-898e-4ce4cc2250b1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=716). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:55.288966 [ 4018 ] {b8328646-230a-4f80-ada1-c84e453c51ff} executeQuery: Code: 57. DB::Exception: Table test.hits_dst already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50728) (comment: 00061_storage_buffer.sql) (in query: CREATE TABLE test.hits_dst AS test.hits ENGINE = MergeTree PARTITION BY toYYYYMM(EventDate) ORDER BY (CounterID, EventDate, intHash32(UserID)) SAMPLE BY intHash32(UserID) SETTINGS storage_policy = 'default', index_granularity = 49674, min_bytes_for_wide_part = 738771639, ratio_of_defaults_for_sparse_serialization = 0.49680179357528687, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 70559890, compact_parts_max_granules_to_buffer = 237, compact_parts_merge_max_bytes_to_prefetch_part = 23277829, merge_max_block_size = 12972, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 5094685288, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3651161560, index_granularity_bytes = 7264767, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 47616, primary_key_compress_block_size = 56885), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:55.291791 [ 4018 ] {b8328646-230a-4f80-ada1-c84e453c51ff} TCPHandler: Code: 57. DB::Exception: Table test.hits_dst 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:27:56.191869 [ 4042 ] {faeea965-8351-42e1-bcb1-dc19d04a8001} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, Title, SearchPhrase FROM test.hits LIMIT 1000. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50780) (comment: 00092_obfuscator.sh) (in query: SELECT URL, Title, SearchPhrase FROM test.hits LIMIT 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:56.193650 [ 4042 ] {faeea965-8351-42e1-bcb1-dc19d04a8001} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, Title, SearchPhrase FROM test.hits LIMIT 1000. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:56.466322 [ 4727 ] {3be72dc3-fccc-4a6a-b365-22a88c5e0e28} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT RegionID, uniqHLL12(WatchID) AS X FROM remote('127.0.0.{1,2}', test, hits) GROUP BY RegionID HAVING X > 100000 ORDER BY RegionID ASC. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50794) (comment: 00146_aggregate_function_uniq.sql) (in query: SELECT RegionID, uniqHLL12(WatchID) AS X FROM remote('127.0.0.{1,2}', test, hits) GROUP BY RegionID HAVING X > 100000 ORDER BY RegionID 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:56.467876 [ 4727 ] {3be72dc3-fccc-4a6a-b365-22a88c5e0e28} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT RegionID, uniqHLL12(WatchID) AS X FROM remote('127.0.0.{1,2}', test, hits) GROUP BY RegionID HAVING X > 100000 ORDER BY RegionID ASC. Maybe you meant: ['WatchIDs']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:56.483179 [ 2879 ] {dda23df1-3f97-4118-9d4f-85e1d3ad4ba7} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT DISTINCT URLHierarchy(URL)[1] AS q, 'x' AS w FROM test.hits WHERE CounterID = 14917930 ORDER BY URL ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50670) (comment: 00017_aggregation_uninitialized_memory.sql) (in query: SELECT DISTINCT (URLHierarchy(URL)[1]) AS q, 'x' AS w FROM test.hits WHERE CounterID = 14917930 ORDER BY URL ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:27:56.485182 [ 2879 ] {dda23df1-3f97-4118-9d4f-85e1d3ad4ba7} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT DISTINCT URLHierarchy(URL)[1] AS q, 'x' AS w FROM test.hits WHERE CounterID = 14917930 ORDER BY URL ASC. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:27:56.673647 [ 4041 ] {8187f9be-9d39-4135-8c5e-c64793a57006} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'StartDate' in scope SELECT CounterID, StartDate, sumState(Sign) AS Visits, uniqState(UserID) AS Users FROM test.visits GROUP BY CounterID, StartDate. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50702) (comment: 00040_aggregating_materialized_view.sql) (in query: CREATE MATERIALIZED VIEW test.basic_00040 ENGINE = AggregatingMergeTree(StartDate, (CounterID, StartDate), 8192) POPULATE AS SELECT CounterID, StartDate, sumState(Sign) AS Visits, uniqState(UserID) AS Users FROM test.visits GROUP BY CounterID, StartDate;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce865f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a72e6 15. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bddb7 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 26. ? @ 0x00007f550c19fac3 27. ? @ 0x00007f550c231850 2025.09.09 14:27:56.675763 [ 4041 ] {8187f9be-9d39-4135-8c5e-c64793a57006} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'StartDate' in scope SELECT CounterID, StartDate, sumState(Sign) AS Visits, uniqState(UserID) AS Users FROM test.visits GROUP BY CounterID, StartDate. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce865f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a72e6 15. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bddb7 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 26. ? @ 0x00007f550c19fac3 27. ? @ 0x00007f550c231850 2025.09.09 14:27:57.272542 [ 2880 ] {3f85c52e-d2c0-462d-a0ee-3cae3dca308b} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40706) (comment: 00165_jit_aggregate_functions.sql) (in query: SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:57.274671 [ 2880 ] {3f85c52e-d2c0-462d-a0ee-3cae3dca308b} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. Maybe you meant: ['WatchIDs']. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:57.503682 [ 2880 ] {db7306f3-b8d4-4511-878f-1de853a167ad} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 32152608. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40724) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 32152608;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:57.505381 [ 2880 ] {db7306f3-b8d4-4511-878f-1de853a167ad} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 32152608. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:27:57.566782 [ 4018 ] {5439ca7c-8684-4a16-a5af-bc533059c9e0} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40736) (comment: 00044_any_left_join_string.sql) (in query: SELECT domain, hits, visits FROM ( SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain ) ANY LEFT JOIN ( SELECT domain(StartURL) AS domain, sum(Sign) AS visits FROM test.visits GROUP BY domain ) USING domain ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ea4dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:27:57.568627 [ 4018 ] {5439ca7c-8684-4a16-a5af-bc533059c9e0} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ea4dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:27:58.620692 [ 4042 ] {e287e008-8591-4fa5-8c47-da6a9b6c10c8} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50806) (comment: 01682_cache_dictionary_complex_key.sql) (in query: DROP DICTIONARY 01682_database_for_cache_dictionary.cache_dictionary_complex_key_simple_attributes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:58.622321 [ 4042 ] {e287e008-8591-4fa5-8c47-da6a9b6c10c8} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:27:59.142977 [ 4042 ] {query_id_memory_bound_merging_484814047} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY CounterID, URL, EventDate ORDER BY URL ASC, EventDate ASC LIMIT 10, 5 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40784) (comment: 00177_memory_bound_merging.sh) (in query: SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE CounterID = 1704509 AND UserID = 4322253409885123546 GROUP BY CounterID, URL, EventDate ORDER BY URL, EventDate LIMIT 5 OFFSET 10 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:59.145193 [ 4042 ] {query_id_memory_bound_merging_484814047} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY CounterID, URL, EventDate ORDER BY URL ASC, EventDate ASC LIMIT 10, 5 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:27:59.969312 [ 2880 ] {cccf7d2d-ca98-486e-a01d-8c1500e46155} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'StartDate' in scope SELECT CounterID, StartDate, Sign, UserID FROM test.visits. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40762) (comment: 00041_aggregating_materialized_view.sql) (in query: INSERT INTO test.visits_null SELECT CounterID, StartDate, Sign, UserID FROM 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9fb23 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:27:59.973004 [ 2880 ] {cccf7d2d-ca98-486e-a01d-8c1500e46155} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'StartDate' in scope SELECT CounterID, StartDate, Sign, UserID FROM test.visits. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 13. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9fb23 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:28:00.604512 [ 4730 ] {d613b9e1-2ca0-4005-91f5-1dfa6b3c7efe} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40788) (comment: 00042_any_left_join.sql) (in query: SELECT EventDate, hits, visits FROM ( SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate ) ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ea4dc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 30. ? @ 0x00007f550c19fac3 31. ? @ 0x00007f550c231850 2025.09.09 14:28:00.606423 [ 4730 ] {d613b9e1-2ca0-4005-91f5-1dfa6b3c7efe} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334ea4dc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 30. ? @ 0x00007f550c19fac3 31. ? @ 0x00007f550c231850 2025.09.09 14:28:00.835000 [ 4727 ] {655afc56-a983-4b08-ae98-a28f89ae3c8e} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.hits WHERE CounterID = 912887. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40820) (comment: 00140_rename.sql) (in query: SELECT sum(Sign) FROM test.hits WHERE CounterID = 912887;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:28:00.837213 [ 4727 ] {655afc56-a983-4b08-ae98-a28f89ae3c8e} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.hits WHERE CounterID = 912887. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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&&) @ 0x00000000334f8c27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344c98b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:28:01.027743 [ 3626 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7aa30d62-5bef-4999-be1c-ed4828d746b7::202509_1_21_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:01.529401 [ 4018 ] {a069befc-5f13-4527-8960-43aacc43d534} 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.10505.altinitytest (altinity build)) (from [::1]:40798) (comment: 02990_parts_splitter_invalid_ranges.sql) (in query: SELECT eventType, timestamp, key FROM test_table WHERE (eventType IN ('2', '4')) AND ((timestamp >= max2(toInt64('1698938519999'), toUnixTimestamp64Milli(now64() - toIntervalDay(90)))) AND (timestamp <= (toInt64('1707143315452') - 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a43d25 7. ./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) @ 0x000000003bf04769 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf16ef9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1c8e0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:28:01.531416 [ 4018 ] {a069befc-5f13-4527-8960-43aacc43d534} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a43d25 7. ./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) @ 0x000000003bf04769 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf16ef9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1c8e0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:28:02.202236 [ 4730 ] {e6a864bd-d870-4ee0-a667-29b2df0fb712} executeQuery: Code: 57. DB::Exception: Table test_15.distinct_in_order already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40836) (comment: 00174_distinct_in_order.sql) (in query: CREATE TABLE distinct_in_order (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., 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 = 433652717, compact_parts_max_granules_to_buffer = 61, compact_parts_merge_max_bytes_to_prefetch_part = 9324531, merge_max_block_size = 5927, old_parts_lifetime = 262., prefer_fetch_merged_part_size_threshold = 84220398, vertical_merge_algorithm_min_rows_to_activate = 32025, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78031, primary_key_compress_block_size = 21207), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:02.203864 [ 4730 ] {e6a864bd-d870-4ee0-a667-29b2df0fb712} TCPHandler: Code: 57. DB::Exception: Table test_15.distinct_in_order 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:04.089366 [ 4041 ] {cf46d223-2ce3-466d-bce2-080d1d7b8670} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40816) (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_484814047' AND initial_query_id = 'query_id_memory_bound_merging_484814047' 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a43d25 7. ./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) @ 0x000000003bf04769 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf16ef9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1c8e0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:28:04.091279 [ 4041 ] {cf46d223-2ce3-466d-bce2-080d1d7b8670} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a43d25 7. ./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) @ 0x000000003bf04769 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf16ef9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1c8e0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:28:06.227001 [ 4621 ] {a4eb960d-b705-4604-8eae-71e4707eb104} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40920) (comment: 00157_cache_dictionary.sql) (in query: DROP DICTIONARY IF EXISTS db_dict.cache_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:28:06.228242 [ 4621 ] {a4eb960d-b705-4604-8eae-71e4707eb104} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:28:07.391610 [ 4730 ] {7fb11546-70c3-4b26-bb3c-1bbbb02f9723} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:5767f64a-164a-4b2a-9452-1e68925ee3b9'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58058) (comment: 00163_column_oriented_formats.sh) (in query: CREATE DATABASE IF NOT EXISTS test_coqjunjd ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:07.393367 [ 4730 ] {7fb11546-70c3-4b26-bb3c-1bbbb02f9723} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:5767f64a-164a-4b2a-9452-1e68925ee3b9'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:07.408895 [ 4730 ] {73d4efc2-0178-4df7-8c53-0826f2b05581} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:314a71b2-5ede-4365-a5a6-39c30a22b90c'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58064) (comment: 00176_distinct_limit_by_limit_bug_43377.sql) (in query: CREATE DATABASE IF NOT EXISTS test_q01sfkzv ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:07.410403 [ 4730 ] {73d4efc2-0178-4df7-8c53-0826f2b05581} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:314a71b2-5ede-4365-a5a6-39c30a22b90c'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:07.424689 [ 4730 ] {0ae3cae5-ff09-4d09-aba3-9bbd5fbc512a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:06a76a4f-92af-4482-a03f-aec45db49492'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58080) (comment: 00092_obfuscator.sh) (in query: CREATE DATABASE IF NOT EXISTS test_fo1yro37 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:07.426345 [ 4730 ] {0ae3cae5-ff09-4d09-aba3-9bbd5fbc512a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:06a76a4f-92af-4482-a03f-aec45db49492'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:07.440734 [ 4730 ] {72789c0f-d73e-4e09-af0d-7cc71625d171} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:d887e0e6-83e6-477f-9e57-f1baa2f56590'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58086) (comment: 00053_replicate_segfault.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ezbkn1ba ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:07.442385 [ 4730 ] {72789c0f-d73e-4e09-af0d-7cc71625d171} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:d887e0e6-83e6-477f-9e57-f1baa2f56590'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:07.514099 [ 4730 ] {9b27141c-99c5-4401-ab3d-1d1f2a665e23} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:64479999-25a0-4197-85ba-e3294188b762'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58102) (comment: 00052_group_by_in.sql) (in query: CREATE DATABASE IF NOT EXISTS test_kt1jsrj3 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:07.515726 [ 4730 ] {9b27141c-99c5-4401-ab3d-1d1f2a665e23} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:64479999-25a0-4197-85ba-e3294188b762'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:07.530287 [ 4730 ] {e0cf7519-2f68-4461-8bb3-0683c726698e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:607d9d62-bbd7-4bf9-90e8-d4b6e53d135a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58112) (comment: 00085_monotonic_evaluation_segfault.sql) (in query: CREATE DATABASE IF NOT EXISTS test_i0gc173c ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:07.531826 [ 4730 ] {e0cf7519-2f68-4461-8bb3-0683c726698e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:607d9d62-bbd7-4bf9-90e8-d4b6e53d135a'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:07.594338 [ 4730 ] {1989a55f-8de6-441a-90bf-6783a525708a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:a9f234b0-cd7c-44d2-b3e2-d56af8229595'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58124) (comment: 00089_position_functions_with_non_constant_arg.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3aejr3ao ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:07.595916 [ 4730 ] {1989a55f-8de6-441a-90bf-6783a525708a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:a9f234b0-cd7c-44d2-b3e2-d56af8229595'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:07.613658 [ 4730 ] {e0f895af-7686-418b-839d-c890251420a7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:1389a584-a786-4c01-bbb6-955cd719f4e7'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58132) (comment: 00014_filtering_arrays.sql) (in query: CREATE DATABASE IF NOT EXISTS test_a0j3ji8n ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:07.615354 [ 4730 ] {e0f895af-7686-418b-839d-c890251420a7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:1389a584-a786-4c01-bbb6-955cd719f4e7'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:07.630737 [ 4730 ] {59d17fc1-ff32-4f33-9114-e096519d7ca5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:9da5a720-048c-4602-befa-7da5695646b7'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58142) (comment: 00151_order_by_read_in_order.sql) (in query: CREATE DATABASE IF NOT EXISTS test_49e7t7ul ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:07.632549 [ 4730 ] {59d17fc1-ff32-4f33-9114-e096519d7ca5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '9cd04cf8cbd3:9000:84af089f-71e0-48e5-a96a-e538189fafe4', current host ID: '9cd04cf8cbd3:9000:9da5a720-048c-4602-befa-7da5695646b7'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032a993e7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a142f4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a24d1d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000003490a0ef 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488a598 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:07.687080 [ 4727 ] {68319123-7de4-4054-8d4b-2c7b3983ad37} executeQuery: Code: 36. DB::Exception: Default codec cannot have any arguments, it's just an alias for codec specified in config.xml. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40982) (comment: 01455_default_compression.sql) (in query: ALTER TABLE compress_table MODIFY COLUMN value2 CODEC(Default(5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845dd8a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000034921b34 5. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809b174 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:28:07.687978 [ 4727 ] {68319123-7de4-4054-8d4b-2c7b3983ad37} TCPHandler: Code: 36. DB::Exception: Default codec cannot have any arguments, it's just an alias for codec specified in config.xml. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000845dd8a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000034921b34 5. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809b174 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:28:10.639756 [ 4134 ] {e8115081-8a8b-490f-a22b-9a1cf124a543} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test.hits_1m (2096918b-7921-4d2e-be2d-c7cc10c66c1a), because some tables depend on it: db_dict.cache_hits. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42912) (comment: 00157_cache_dictionary.sql) (in query: DROP TABLE IF EXISTS test.hits_1m;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x00000000339e47cd 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c9c1f 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339cb339 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034930182 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:10.641328 [ 4134 ] {e8115081-8a8b-490f-a22b-9a1cf124a543} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test.hits_1m (2096918b-7921-4d2e-be2d-c7cc10c66c1a), 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x00000000339e47cd 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c9c1f 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339cb339 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034930182 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:28:11.259632 [ 4727 ] {16b0b4f5-49b9-4917-b70b-5fad7198ba94} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(1, 2, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42884) (comment: 03130_generateSnowflakeId.sql) (in query: SELECT generateSnowflakeID(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008402a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fccc9 5. DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe599a4 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 2025.09.09 14:28:11.260651 [ 4727 ] {16b0b4f5-49b9-4917-b70b-5fad7198ba94} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(1, 2, 3). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000008402a57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fccc9 5. DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe599a4 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 2025.09.09 14:28:11.385273 [ 4134 ] {627f9b0d-af52-47ab-b6db-6c944a41a579} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42968) (comment: 00095_hyperscan_profiler.sql) (in query: SELECT count() FROM test.hits WHERE multiFuzzyMatchAny(URL, 2, ['about/address', 'for_woman', '^https?://lm-company.ruy/$', 'ultimateguitar.com']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:11.387686 [ 4134 ] {627f9b0d-af52-47ab-b6db-6c944a41a579} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:13.366432 [ 4727 ] {a5ac1eb5-4f91-4272-8d90-26e0e972684b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: String: In scope SELECT generateSnowflakeID(1, 'not_an_int'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42884) (comment: 03130_generateSnowflakeId.sql) (in query: SELECT generateSnowflakeID(1, 'not_an_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 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&&) @ 0x00000000084046a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fd8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fc035 6. DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe599a4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:13.367732 [ 4727 ] {a5ac1eb5-4f91-4272-8d90-26e0e972684b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: String: In scope SELECT generateSnowflakeID(1, 'not_an_int'). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 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&&) @ 0x00000000084046a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fd8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fc035 6. DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe599a4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:13.379469 [ 4727 ] {632bb02d-de1f-428e-8bd0-949be3bb1ba5} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: UInt8: In scope SELECT generateSnowflakeID(1, materialize(2)). (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42884) (comment: 03130_generateSnowflakeId.sql) (in query: SELECT generateSnowflakeID(1, materialize(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 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&&) @ 0x00000000084046a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fd8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fc035 6. DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe599a4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:13.380246 [ 4727 ] {632bb02d-de1f-428e-8bd0-949be3bb1ba5} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: UInt8: In scope SELECT generateSnowflakeID(1, materialize(2)). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 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&&) @ 0x00000000084046a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fd8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fc035 6. DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fe599a4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:18.201215 [ 4621 ] {a344ffb2-d2dd-4991-a132-59455467480f} executeQuery: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53250) (comment: 02391_hashed_dictionary_shards.sql) (in query: CREATE TABLE test_table ( key UInt64, value UInt16 ) ENGINE=Memory() AS SELECT number, number FROM numbers(1e5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:18.202524 [ 4621 ] {a344ffb2-d2dd-4991-a132-59455467480f} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:20.122053 [ 4082 ] {1435d49d-f4f4-4f21-82d1-725e5da32b79} executeQuery: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFC(value). (CANNOT_NORMALIZE_STRING) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53216) (comment: 02011_normalize_utf8.sql) (in query: SELECT char(228) AS value, normalizeUTF8NFC(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFCImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da0e4d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:20.123334 [ 4082 ] {1435d49d-f4f4-4f21-82d1-725e5da32b79} TCPHandler: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFC(value). (CANNOT_NORMALIZE_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFCImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da0e4d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:21.201221 [ 4730 ] {06830b53-0202-49df-9819-72f235bc89f2} executeQuery: Code: 60. DB::Exception: Table test_3.receiver_02572 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53262) (comment: 02572_materialized_views_ignore_errors.sql) (in query: -- ensure that insert fails insert into proxy_02572 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8f56f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034baa2e8 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x0000000039323956 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000039313506 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000003930fc14 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb2a6c4 13. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b803ce9 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b8024a7 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 19. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aecc419 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abd27aa 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:28:21.203042 [ 4730 ] {06830b53-0202-49df-9819-72f235bc89f2} TCPHandler: Code: 60. DB::Exception: Table test_3.receiver_02572 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8f56f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034baa2e8 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x0000000039323956 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000039313506 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000003930fc14 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb2a6c4 13. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b803ce9 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b8024a7 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 19. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aecc419 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abd27aa 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:28:21.464920 [ 4730 ] {2cc90df2-8c84-40eb-8d95-dc4322f39481} PushingToViews: Cannot push to the storage, ignoring the error: Code: 60. DB::Exception: Table test_3.receiver_02572 does not exist: while pushing to view test_3.push_to_proxy_mv_02572 (2c09e205-342e-43c0-a20d-22b4149e214d). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8f56f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034baa2e8 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x0000000039323956 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000039313506 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000003930fc14 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb2a6c4 13. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b803ce9 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b8024a7 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 19. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aecc419 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abd27aa 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:21.964138 [ 4082 ] {894869c7-591f-4508-b1a0-58031b464834} executeQuery: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFD(value). (CANNOT_NORMALIZE_STRING) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53216) (comment: 02011_normalize_utf8.sql) (in query: SELECT char(228) AS value, normalizeUTF8NFD(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFDImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da3c2d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:21.965410 [ 4082 ] {894869c7-591f-4508-b1a0-58031b464834} TCPHandler: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFD(value). (CANNOT_NORMALIZE_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFDImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da3c2d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:24.102597 [ 4082 ] {04964280-1b6a-4c96-bcdc-860644bd1a67} executeQuery: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFKC(value). (CANNOT_NORMALIZE_STRING) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53216) (comment: 02011_normalize_utf8.sql) (in query: SELECT char(228) AS value, normalizeUTF8NFKC(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFKCImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da6a0d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:24.103541 [ 4082 ] {04964280-1b6a-4c96-bcdc-860644bd1a67} TCPHandler: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFKC(value). (CANNOT_NORMALIZE_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFKCImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da6a0d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:25.226126 [ 4730 ] {b5b5f242-1bbb-4e62-bc3d-dfcd71036548} executeQuery: Code: 60. DB::Exception: Table test_3.receiver_02572 does not exist: while pushing to view test_3.push_to_proxy_mv_02572 (2c09e205-342e-43c0-a20d-22b4149e214d). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53262) (comment: 02572_materialized_views_ignore_errors.sql) (in query: -- materialized_views_ignore_errors=0 insert into data_02572 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8f56f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034baa2e8 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x0000000039323956 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000039313506 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000003930fc14 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb2a6c4 13. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b803ce9 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b8024a7 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 19. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aecc419 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abd27aa 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:28:25.228975 [ 4730 ] {b5b5f242-1bbb-4e62-bc3d-dfcd71036548} TCPHandler: Code: 60. DB::Exception: Table test_3.receiver_02572 does not exist: while pushing to view test_3.push_to_proxy_mv_02572 (2c09e205-342e-43c0-a20d-22b4149e214d). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b8f56f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034baa2e8 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x0000000039323956 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000039313506 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000003930fc14 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb2a6c4 13. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b803ce9 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b8024a7 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 19. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aecc419 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abd27aa 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 2025.09.09 14:28:26.510703 [ 4041 ] {8ad529cf-f173-4e03-9e05-d667d01fe14d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53392) (comment: 02477_logical_expressions_optimizer_low_cardinality.sql) (in query: EXPLAIN QUERY TREE SELECT a FROM t_logical_expressions_optimizer_low_cardinality WHERE b <> 0 AND b <> 1 SETTINGS enable_analyzer = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:26.511895 [ 4041 ] {8ad529cf-f173-4e03-9e05-d667d01fe14d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:27.230928 [ 4082 ] {da6cac71-db79-4c7f-85d3-e73b380700a7} executeQuery: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFKD(value). (CANNOT_NORMALIZE_STRING) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53216) (comment: 02011_normalize_utf8.sql) (in query: SELECT char(228) AS value, normalizeUTF8NFKD(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFKDImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da97ed 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:27.232094 [ 4082 ] {da6cac71-db79-4c7f-85d3-e73b380700a7} TCPHandler: Code: 621. DB::Exception: Normalization failed (strFromUTF8): U_INVALID_CHAR_FOUND: In scope SELECT char(228) AS value, normalizeUTF8NFKD(value). (CANNOT_NORMALIZE_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. DB::FunctionStringToString, DB::(anonymous namespace)::NormalizeNFKDImpl, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018da97ed 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:28.238356 [ 4621 ] {8a4fcc3d-9906-4da1-943f-e4fe5e6c5606} 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.10505.altinitytest (altinity build)) (from [::1]:55840) (comment: 00095_hyperscan_profiler.sql) (in query: SELECT count() FROM test.hits WHERE multiFuzzyMatchAny(URL, 2, ['about/address', 'for_woman', '^https?://lm-company.ruy/$', 'ultimateguitar.com']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:28.300922 [ 4621 ] {8a4fcc3d-9906-4da1-943f-e4fe5e6c5606} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:30.295048 [ 4134 ] {834b5200-00b6-4baa-8fea-ef3d66df4560} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55916) (comment: 02841_tuple_modulo.sql) (in query: SELECT (5,4) % 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:30.297214 [ 4134 ] {834b5200-00b6-4baa-8fea-ef3d66df4560} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:31.200268 [ 7627 ] {622b2d5e-666e-4fa8-9972-c5c6cee79f29} 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.10505.altinitytest (altinity build)) (from [::1]:55886) (comment: 01660_system_parts_smoke.sql) (in query: SELECT count(), _state FROM system.parts WHERE database = currentDatabase() AND table = 'data_01660' GROUP BY _state ORDER BY _state;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:31.202650 [ 7627 ] {622b2d5e-666e-4fa8-9972-c5c6cee79f29} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:32.298819 [ 4041 ] {5110fe4c-bbd5-4670-8974-3e2dbff32a82} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33050) (comment: 00159_parallel_formatting_http.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a,MobilePhoneModel as b,ClientIP6 as c FROM test.hits ORDER BY a,b,c LIMIT 1000000 Format JSONCompactEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3a05c8 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aed9272 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 15. ./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&)>) @ 0x00000000358b9e13 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:28:32.304003 [ 4041 ] {5110fe4c-bbd5-4670-8974-3e2dbff32a82} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3a05c8 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aed9272 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 15. ./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&)>) @ 0x00000000358b9e13 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:32.703899 [ 4621 ] {1ea25a40-e772-4a88-88ad-9d934d756536} 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.10505.altinitytest (altinity build)) (from [::1]:55846) (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_26285820' AND initial_query_id = 'query_id_memory_bound_merging_26285820' 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a43d25 7. ./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) @ 0x000000003bf04769 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c183529 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1040cb 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be928ba 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8f80c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:28:32.705793 [ 4621 ] {1ea25a40-e772-4a88-88ad-9d934d756536} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a43d25 7. ./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) @ 0x000000003bf04769 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:0: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c183529 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1040cb 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be928ba 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8f80c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:28:32.736270 [ 7641 ] {0a651b8b-5dad-4916-b414-5206f167312f} executeQuery: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is String. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55926) (comment: 03198_dictionary_validate_primary_key_type.sql) (in query: CREATE DICTIONARY `test_dictionary1` ( `n1` String, `n2` UInt32 ) PRIMARY KEY n1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 DB 'test_db' TABLE 'table_01' USER 'default')) LIFETIME(MIN 1 MAX 10) LAYOUT(FLAT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:61: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x0000000038244abf 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x0000000038245b05 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x00000000382464a9 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038253b2a 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038253823 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824f280 10. ./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 @ 0x00000000382f6666 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:28:32.737280 [ 7641 ] {0a651b8b-5dad-4916-b414-5206f167312f} TCPHandler: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is String. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:61: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x0000000038244abf 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x0000000038245b05 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x00000000382464a9 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038253b2a 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038253823 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824f280 10. ./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 @ 0x00000000382f6666 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:28:32.754614 [ 7641 ] {814be910-8f09-4e11-bcc8-4278d61159ea} executeQuery: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is UInt32. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55926) (comment: 03198_dictionary_validate_primary_key_type.sql) (in query: CREATE DICTIONARY `test_dictionary2` ( `n1` UInt32, `n2` UInt32 ) PRIMARY KEY n1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 DB 'test_db' TABLE 'table_01' USER 'default')) LIFETIME(MIN 1 MAX 10) LAYOUT(FLAT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:61: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x0000000038244abf 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x0000000038245b05 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x00000000382464a9 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038253b2a 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038253823 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824f280 10. ./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 @ 0x00000000382f6666 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:28:32.755775 [ 7641 ] {814be910-8f09-4e11-bcc8-4278d61159ea} TCPHandler: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is UInt32. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409c30a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:61: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x0000000038244abf 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x0000000038245b05 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x00000000382464a9 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038253b2a 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038253823 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003824f280 10. ./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 @ 0x00000000382f6666 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:28:33.282910 [ 4134 ] {800f6eae-45ba-4e66-9212-13d021163f8e} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55942) (comment: 02918_analyzer_to_ast_crash.sql) (in query: WITH x AS (SELECT in((SELECT * FROM y))), y AS (SELECT 1) SELECT * FROM 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2859: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334aecca 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 29. ? @ 0x00007f550c19fac3 30. ? @ 0x00007f550c231850 2025.09.09 14:28:33.284449 [ 4134 ] {800f6eae-45ba-4e66-9212-13d021163f8e} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2859: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334aecca 5. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 29. ? @ 0x00007f550c19fac3 30. ? @ 0x00007f550c231850 2025.09.09 14:28:33.718039 [ 7738 ] {2fa1532c-1312-4900-8cb9-98d859af58ac} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44388) (comment: 00177_memory_bound_merging.sh) (in query: SELECT `__table1`.`URL` AS `URL`, `__table1`.`EventDate` AS `EventDate`, `__table1`.`URL` AS `max(URL)` FROM `test`.`hits` AS `__table1` WHERE (`__table1`.`CounterID` = 1704509) AND (`__table1`.`UserID` = 4322253409885123546) GROUP BY `__table1`.`URL`, `__table1`.`EventDate` ORDER BY `__table1`.`URL` ASC, `__table1`.`EventDate` ASC LIMIT _CAST(10, 'UInt64'), _CAST(5, '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:33.720659 [ 7738 ] {2fa1532c-1312-4900-8cb9-98d859af58ac} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:34.404603 [ 7694 ] {query_id_memory_bound_merging_77944020} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55982) (comment: 00177_memory_bound_merging.sh) (in query: SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE CounterID = 1704509 AND UserID = 4322253409885123546 GROUP BY URL, EventDate ORDER BY URL, EventDate LIMIT 5 OFFSET 10 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3, query_plan_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019c0b2 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7bd30c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d8b1b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8c6cf8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:28:34.409882 [ 7694 ] {query_id_memory_bound_merging_77944020} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 : 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019c0b2 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7bd30c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d8b1b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8c6cf8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:28:35.124381 [ 7737 ] {5fe90b90-70a3-4ce0-b214-09db37723dd1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55994) (comment: 02096_date_time_1970_saturation.sql) (in query: select toStartOfFiveMinutes(toDateTime(0, 'America/Los_Angeles'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:35.126286 [ 7737 ] {5fe90b90-70a3-4ce0-b214-09db37723dd1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:36.144332 [ 3625 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {099aa52d-ff08-48bf-87ed-79cf97f266be::202509_1_32_8}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009cb0d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x00000000200978df 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7e39f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011a21f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3aa5f2 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a73f4 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:36.533016 [ 4134 ] {5915efa6-ddcd-42f6-b2a6-ce57424446e0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56026) (comment: 00148_monotonic_functions_and_index.sql) (in query: SELECT count() FROM test.hits WHERE -CounterID >= -732797 AND CounterID >= 107931;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:36.535127 [ 4134 ] {5915efa6-ddcd-42f6-b2a6-ce57424446e0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:37.943441 [ 4080 ] {e18c413e-1018-47e9-9a7c-0372c484a511} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3a6e19 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000003b3a1dd6 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000003b3af0cf 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3aed5f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:37.955445 [ 4041 ] {e18c413e-1018-47e9-9a7c-0372c484a511} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelParsingBlockInputFormat: While executing ShellCommandSource: While executing SourceFromQueryPipeline: while executing 'FUNCTION dictGet('executable_complex_direct'_String :: 1, 'b'_String :: 3, tuple(__table1.number, __table1.number) :: 4) -> dictGet('executable_complex_direct'_String, 'b'_String, tuple(__table1.number, __table1.number)) UInt64 : 2'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56038) (comment: 01474_executable_dictionary.sql) (in query: SELECT number, dictGet('executable_complex_direct', 'a', (number, number)) AS a, dictGet('executable_complex_direct', 'b', (number, number)) AS b FROM numbers(1000000) WHERE number = 999999;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3a6e19 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000003b3a1dd6 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000003b3af0cf 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3aed5f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:37.957987 [ 4041 ] {e18c413e-1018-47e9-9a7c-0372c484a511} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelParsingBlockInputFormat: While executing ShellCommandSource: While executing SourceFromQueryPipeline: while executing 'FUNCTION dictGet('executable_complex_direct'_String :: 1, 'b'_String :: 3, tuple(__table1.number, __table1.number) :: 4) -> dictGet('executable_complex_direct'_String, 'b'_String, tuple(__table1.number, __table1.number)) UInt64 : 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3a6e19 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000003b3a1dd6 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000003b3af0cf 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3aed5f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:39.628269 [ 7738 ] {af9896bd-5a6d-4fe5-a5c3-9f7e41062939} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41224) (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 = 6896, min_bytes_for_wide_part = 15110720, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 95, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 238297740, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 33288896, merge_max_block_size = 19672, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 8283759838, vertical_merge_algorithm_min_rows_to_activate = 244091, vertical_merge_algorithm_min_columns_to_activate = 78, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 30171287, concurrent_part_removal_threshold = 80, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 73425, primary_key_compress_block_size = 48902), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:39.629419 [ 7738 ] {af9896bd-5a6d-4fe5-a5c3-9f7e41062939} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:40.725655 [ 4134 ] {2d2c0c27-280b-4121-97e3-f3df694092d3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41294) (comment: 02122_parallel_formatting_RowBinaryWithNames.sh) (in query: select number, number + 1, concat('string: ', toString(number)) from numbers(200000) format RowBinaryWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:40.727513 [ 4134 ] {2d2c0c27-280b-4121-97e3-f3df694092d3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:42.373124 [ 7738 ] {20378454-1ca8-4208-9d79-04d1a8f42736} executeQuery: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41254) (comment: 01821_join_table_mutation.sql) (in query: ALTER TABLE join_table_mutation UPDATE name = 'some' 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Storages/StorageJoin.cpp:165: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x00000000383f9cd3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b917 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:42.373934 [ 7738 ] {20378454-1ca8-4208-9d79-04d1a8f42736} TCPHandler: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Storages/StorageJoin.cpp:165: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x00000000383f9cd3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b917 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:43.232916 [ 4621 ] {fa6a9ef7-2189-4726-873b-6006653d5caa} 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.10505.altinitytest (altinity build)) (from [::1]:41340) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT count() IN (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID)) FROM test.hits WHERE NOT ignore(AdvEngineID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:43.235414 [ 4621 ] {fa6a9ef7-2189-4726-873b-6006653d5caa} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:44.173711 [ 7738 ] {d6ccc6ad-97b0-499b-b37c-d8bf391e9a76} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41382) (comment: 00171_grouping_aggregated_transform_bug.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 max_block_size = 63169;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:44.179231 [ 7738 ] {d6ccc6ad-97b0-499b-b37c-d8bf391e9a76} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:44.235153 [ 7627 ] {62455086-77bf-4ae3-a7fa-af432d54ea1a} executeQuery: Code: 57. DB::Exception: Table test_ahplsuxe.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41400) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:44.237445 [ 7627 ] {62455086-77bf-4ae3-a7fa-af432d54ea1a} TCPHandler: Code: 57. DB::Exception: Table test_ahplsuxe.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:45.343339 [ 4134 ] {3ec828e9-503a-486a-8df3-e90cd54f1057} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:44688). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44688) (comment: 00171_grouping_aggregated_transform_bug.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abe7995 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5570 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:28:45.353892 [ 4041 ] {c5b7739f-eada-4d40-bb3b-482ba51aa5bd} executeQuery: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: String, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(\'abc\')'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT CAST(1 as DateTime64('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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x00000000326280e1 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::create64(std::shared_ptr const&) @ 0x0000000032625e48 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323657da 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a96f1 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x00000000323a85c9 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x00000000323a2b57 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008391dbb 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b608fd4 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:28:45.355087 [ 4041 ] {c5b7739f-eada-4d40-bb3b-482ba51aa5bd} TCPHandler: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: String, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(\'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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x00000000326280e1 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::create64(std::shared_ptr const&) @ 0x0000000032625e48 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323657da 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a96f1 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x00000000323a85c9 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x00000000323a2b57 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008391dbb 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b608fd4 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:28:46.302963 [ 4134 ] {3ec828e9-503a-486a-8df3-e90cd54f1057} 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]:44688). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0729a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd8e6a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2fa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:28:46.303552 [ 4134 ] {3ec828e9-503a-486a-8df3-e90cd54f1057} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:44688). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abe7995 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5570 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:28:46.304268 [ 4134 ] {3ec828e9-503a-486a-8df3-e90cd54f1057} TCPHandler: Client has gone away. 2025.09.09 14:28:46.520202 [ 4041 ] {51390a42-d052-48eb-b6bc-8ea2ba961c30} executeQuery: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT CAST(1, 'DateTime64(100)'). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT CAST(1 as DateTime64(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a98cd 4. ./src/DataTypes/DataTypeDecimalBase.h:78: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000003237b851 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375726 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], unsigned long const&, String, void>(std::allocator const&, unsigned long const&, String&&) @ 0x0000000032626f3b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create64(std::shared_ptr const&) @ 0x00000000326262c3 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323657da 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a96f1 10. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x00000000323a85c9 11. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x00000000323a2b57 12. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008391dbb 13. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b608fd4 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 2025.09.09 14:28:46.521656 [ 4041 ] {51390a42-d052-48eb-b6bc-8ea2ba961c30} TCPHandler: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT CAST(1, 'DateTime64(100)'). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a98cd 4. ./src/DataTypes/DataTypeDecimalBase.h:78: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000003237b851 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375726 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], unsigned long const&, String, void>(std::allocator const&, unsigned long const&, String&&) @ 0x0000000032626f3b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create64(std::shared_ptr const&) @ 0x00000000326262c3 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323657da 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a96f1 10. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x00000000323a85c9 11. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x00000000323a2b57 12. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008391dbb 13. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b608fd4 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 2025.09.09 14:28:46.535768 [ 4041 ] {0ffd4f7c-4f70-4d5d-beef-6429c3118a55} executeQuery: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: Int64, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(-1)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT CAST(1 as DateTime64(-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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x00000000326280e1 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::create64(std::shared_ptr const&) @ 0x0000000032625e48 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323657da 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a96f1 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x00000000323a85c9 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x00000000323a2b57 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008391dbb 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b608fd4 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:28:46.536726 [ 4041 ] {0ffd4f7c-4f70-4d5d-beef-6429c3118a55} TCPHandler: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: Int64, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(-1)'). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x00000000326280e1 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::create64(std::shared_ptr const&) @ 0x0000000032625e48 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323657da 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a96f1 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x00000000323a85c9 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x00000000323a2b57 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008391dbb 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b608fd4 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:28:47.804623 [ 7682 ] {79acfdc5-bfc6-4196-a64a-b99e3b0ad0cd} executeQuery: Code: 57. DB::Exception: Table test_ahplsuxe.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58728) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:47.806307 [ 7682 ] {79acfdc5-bfc6-4196-a64a-b99e3b0ad0cd} TCPHandler: Code: 57. DB::Exception: Table test_ahplsuxe.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:48.138580 [ 7641 ] {d3260ed2-6e54-4733-aa54-8d666e276369} executeQuery: Code: 12. DB::Exception: Exceeded limit for `max_streams` with `max_streams_to_max_threads_ratio`. Make sure that `max_streams * max_streams_to_max_threads_ratio` is in some reasonable boundaries, current value: -9.453956e+21. (PARAMETER_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58688) (comment: 03148_setting_max_streams_to_max_threads_ratio_overflow.sql) (in query: SELECT * FROM test_table SETTINGS max_threads = 1025, max_streams_to_max_threads_ratio = -9223372036854775808, enable_analyzer = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, float&) @ 0x000000001c6281ea 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:732: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d7cd94 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 7. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 8. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:28:48.143240 [ 7641 ] {d3260ed2-6e54-4733-aa54-8d666e276369} TCPHandler: Code: 12. DB::Exception: Exceeded limit for `max_streams` with `max_streams_to_max_threads_ratio`. Make sure that `max_streams * max_streams_to_max_threads_ratio` is in some reasonable boundaries, current value: -9.453956e+21. (PARAMETER_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, float&) @ 0x000000001c6281ea 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:732: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d7cd94 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 7. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 8. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:28:48.188120 [ 4041 ] {5fa1bf48-d438-4f74-a16c-add6eb96c28f} executeQuery: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT CAST(1, 'DateTime64(3, \'qqq\')'). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT CAST(1 as DateTime64(3, 'qqq'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe8227 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd94b6 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000032374b1a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375732 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], unsigned long const&, String, void>(std::allocator const&, unsigned long const&, String&&) @ 0x0000000032626f3b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create64(std::shared_ptr const&) @ 0x00000000326262c3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323657da 11. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a96f1 12. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x00000000323a85c9 13. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x00000000323a2b57 14. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008391dbb 15. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 16. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b608fd4 17. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 2025.09.09 14:28:48.189660 [ 4041 ] {5fa1bf48-d438-4f74-a16c-add6eb96c28f} TCPHandler: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT CAST(1, 'DateTime64(3, \'qqq\')'). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe8227 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd94b6 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000032374b1a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375732 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], unsigned long const&, String, void>(std::allocator const&, unsigned long const&, String&&) @ 0x0000000032626f3b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create64(std::shared_ptr const&) @ 0x00000000326262c3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000323657da 11. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a96f1 12. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x00000000323a85c9 13. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x00000000323a2b57 14. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008391dbb 15. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 16. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b608fd4 17. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 2025.09.09 14:28:49.753694 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:28:50.597988 [ 4041 ] {f33b8519-2ac2-4bf2-a184-bcf8f341c6c1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: String: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT toDateTime64('2019-09-16 19:20:11.234', '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 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&&) @ 0x00000000084046a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fd8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbfba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000093d6fb4 7. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000093881d5 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:50.599254 [ 4041 ] {f33b8519-2ac2-4bf2-a184-bcf8f341c6c1} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: String: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 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&&) @ 0x00000000084046a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fd8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbfba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000093d6fb4 7. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000093881d5 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:51.703165 [ 7682 ] {8a061088-7e80-4b4c-9578-c653d86fae42} executeQuery: Code: 57. DB::Exception: Table test_ahplsuxe.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58822) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:51.705345 [ 7682 ] {8a061088-7e80-4b4c-9578-c653d86fae42} TCPHandler: Code: 57. DB::Exception: Table test_ahplsuxe.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:52.735870 [ 4041 ] {a38cfcc9-0c7a-404c-ac74-58ff83eb5d81} executeQuery: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 100). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT toDateTime64('2019-09-16 19:20:11.234', 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a98cd 4. ./src/DataTypes/DataTypeDecimalBase.h:78: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000003237b851 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375726 6. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x00000000095e20db 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000093d7102 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000093881d5 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:28:52.737026 [ 4041 ] {a38cfcc9-0c7a-404c-ac74-58ff83eb5d81} TCPHandler: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 100). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a98cd 4. ./src/DataTypes/DataTypeDecimalBase.h:78: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000003237b851 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375726 6. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x00000000095e20db 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000093d7102 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000093881d5 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:28:52.755865 [ 4041 ] {c98df343-07e8-4886-bf41-28045a4256c3} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: UInt64: In scope SELECT toDateTime64(CAST([['CLb5Ph ']], 'String'), uniqHLL12('2Gs1V', 752)). (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT toDateTime64(CAST([['CLb5Ph ']], 'String'), uniqHLL12('2Gs1V', 752));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 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&&) @ 0x00000000084046a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fd8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbfba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000093d6fb4 7. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000093881d5 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:52.756953 [ 4041 ] {c98df343-07e8-4886-bf41-28045a4256c3} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: UInt64: In scope SELECT toDateTime64(CAST([['CLb5Ph ']], 'String'), uniqHLL12('2Gs1V', 752)). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 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&&) @ 0x00000000084046a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083fd8e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fbfba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000093d6fb4 7. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000093881d5 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 2025.09.09 14:28:54.392245 [ 4041 ] {1c9c88db-487a-40c8-8142-2e0a9570fe2c} executeQuery: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 3, 'qqq'). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT toDateTime64('2019-09-16 19:20:11.234', 3, 'qqq');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe8227 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd94b6 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000032374b1a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375732 8. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x00000000095e20db 9. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000093d7102 10. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000093881d5 11. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 2025.09.09 14:28:54.393839 [ 4041 ] {1c9c88db-487a-40c8-8142-2e0a9570fe2c} TCPHandler: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 3, 'qqq'). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe8227 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd94b6 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000032374b1a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375732 8. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x00000000095e20db 9. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000093d7102 10. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000093881d5 11. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 2025.09.09 14:28:56.197185 [ 4041 ] {9703ecc3-4cca-4cce-b3e0-1e1da9cefd89} executeQuery: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(gccMurmurHash())). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT ignore(now64(gccMurmurHash()));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad1087 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:56.198817 [ 4041 ] {9703ecc3-4cca-4cce-b3e0-1e1da9cefd89} TCPHandler: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(gccMurmurHash())). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad1087 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:56.215680 [ 4041 ] {6fdfa4b2-cff1-40d7-a25b-ce189795a9cf} executeQuery: Code: 43. DB::Exception: Illegal type String of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64('abcd')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT ignore(now64('abcd'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad1087 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:56.216560 [ 4041 ] {6fdfa4b2-cff1-40d7-a25b-ce189795a9cf} TCPHandler: Code: 43. DB::Exception: Illegal type String of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64('abcd')). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad1087 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:56.259558 [ 4041 ] {ccb0c7b2-46fa-4874-a8d8-a1f6ac05cf5a} executeQuery: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(number)) FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT ignore(now64(number)) FROM system.numbers 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad1087 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:56.260693 [ 4041 ] {ccb0c7b2-46fa-4874-a8d8-a1f6ac05cf5a} TCPHandler: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(number)) FROM system.numbers LIMIT 10. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad1087 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:28:57.139820 [ 7644 ] {41f24562-95c7-4ad2-a41a-4c34602c2309} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45072) (comment: 00077_log_tinylog_stripelog.sql) (in query: CHECK TABLE test.hits_tinylog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:57.141951 [ 7644 ] {41f24562-95c7-4ad2-a41a-4c34602c2309} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:28:57.781402 [ 4041 ] {8489e539-4eac-49e6-bca5-4cc621849eda} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid timezone: In scope SELECT ignore(now64(3, 'invalid timezone')). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT ignore(now64(3, 'invalid timezone'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe8227 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd94b6 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000032374b1a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375732 8. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String&, void>(std::allocator const&, unsigned int&, String&) @ 0x0000000015faaa1b 9. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad0b0e 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 2025.09.09 14:28:57.782726 [ 4041 ] {8489e539-4eac-49e6-bca5-4cc621849eda} TCPHandler: Code: 36. DB::Exception: Cannot load time zone invalid timezone: In scope SELECT ignore(now64(3, 'invalid timezone')). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe8227 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd94b6 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000032374b1a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000032375732 8. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String&, void>(std::allocator const&, unsigned int&, String&) @ 0x0000000015faaa1b 9. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad0b0e 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 2025.09.09 14:28:58.132590 [ 7694 ] {a0a5173b-f357-4b7c-a83f-ac1943f17c27} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45106) (comment: 00030_array_enumerate_uniq.sql) (in query: SELECT max(arrayJoin(arrayEnumerateUniq(arrayMap(x -> intDiv(x, 10), URLCategories)))) 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:28:58.199104 [ 7694 ] {a0a5173b-f357-4b7c-a83f-ac1943f17c27} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:29:00.050831 [ 4041 ] {db864efb-95e9-40e5-873e-973a669d873e} executeQuery: Code: 44. DB::Exception: Illegal column 1111 of time zone argument of function, must be a constant string: In scope SELECT ignore(now64(3, 1111)). (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41370) (comment: 00921_datetime64_basic.sql) (in query: SELECT ignore(now64(3, 1111));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9567f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f956cb1 6. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad09ff 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:29:00.052309 [ 4041 ] {db864efb-95e9-40e5-873e-973a669d873e} TCPHandler: Code: 44. DB::Exception: Illegal column 1111 of time zone argument of function, must be a constant string: In scope SELECT ignore(now64(3, 1111)). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000000f9567f2 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000000f956cb1 6. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ad09ff 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033494795 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:29:00.136980 [ 4063 ] {1b1d7fd0-143c-41ff-9ee3-296612ef83cf} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: You have carriage return (\r, 0x0D, ASCII 13) at end of first row. It's like your input data has DOS/Windows style line separators, that are illegal in TabSeparated format. You must transform your file to Unix format. But if you really need carriage return at end of string value of last column, you need to escape it as \r or else enable setting 'input_format_tsv_crlf_end_of_line': (while reading header). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:30: DB::checkForCarriageReturn(DB::ReadBuffer&) @ 0x000000003b6a040e 5. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:106: DB::TabSeparatedFormatReader::skipRowEndDelimiter() @ 0x000000003b6a00aa 6. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:0: std::vector> DB::TabSeparatedFormatReader::readRowImpl() @ 0x000000003b6abf38 7. ./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.h:69: DB::TabSeparatedFormatReader::readRowForHeaderDetection() @ 0x000000003b6aad8e 8. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x000000003b0a8919 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b0a6254 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b03c561 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aed3839 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 14. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b3a7f85 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b3a32e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3aadbc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:29:00.139791 [ 7644 ] {1b1d7fd0-143c-41ff-9ee3-296612ef83cf} executeQuery: Code: 117. DB::Exception: You have carriage return (\r, 0x0D, ASCII 13) at end of first row. It's like your input data has DOS/Windows style line separators, that are illegal in TabSeparated format. You must transform your file to Unix format. But if you really need carriage return at end of string value of last column, you need to escape it as \r or else enable setting 'input_format_tsv_crlf_end_of_line': (while reading header): (in file/uri /var/lib/clickhouse/user_files/02973_parse_crlf_with_tsv_files_test_3_data_with_crlf.tsv): While executing ParallelParsingBlockInputFormat: While executing File. (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45114) (comment: 02973_parse_crlf_with_tsv_files.sh) (in query: SELECT * FROM file(02973_parse_crlf_with_tsv_files_test_3_data_with_crlf.tsv, 'TabSeparated', 'SearchTerm String, Date Date, Hits UInt32');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:30: DB::checkForCarriageReturn(DB::ReadBuffer&) @ 0x000000003b6a040e 5. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:106: DB::TabSeparatedFormatReader::skipRowEndDelimiter() @ 0x000000003b6a00aa 6. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:0: std::vector> DB::TabSeparatedFormatReader::readRowImpl() @ 0x000000003b6abf38 7. ./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.h:69: DB::TabSeparatedFormatReader::readRowForHeaderDetection() @ 0x000000003b6aad8e 8. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x000000003b0a8919 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b0a6254 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b03c561 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aed3839 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 14. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b3a7f85 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b3a32e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3aadbc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 2025.09.09 14:29:00.197167 [ 7644 ] {1b1d7fd0-143c-41ff-9ee3-296612ef83cf} TCPHandler: Code: 117. DB::Exception: You have carriage return (\r, 0x0D, ASCII 13) at end of first row. It's like your input data has DOS/Windows style line separators, that are illegal in TabSeparated format. You must transform your file to Unix format. But if you really need carriage return at end of string value of last column, you need to escape it as \r or else enable setting 'input_format_tsv_crlf_end_of_line': (while reading header): (in file/uri /var/lib/clickhouse/user_files/02973_parse_crlf_with_tsv_files_test_3_data_with_crlf.tsv): While executing ParallelParsingBlockInputFormat: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:30: DB::checkForCarriageReturn(DB::ReadBuffer&) @ 0x000000003b6a040e 5. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:106: DB::TabSeparatedFormatReader::skipRowEndDelimiter() @ 0x000000003b6a00aa 6. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:0: std::vector> DB::TabSeparatedFormatReader::readRowImpl() @ 0x000000003b6abf38 7. ./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.h:69: DB::TabSeparatedFormatReader::readRowForHeaderDetection() @ 0x000000003b6aad8e 8. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x000000003b0a8919 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b0a6254 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b03c561 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aed3839 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 14. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b3a7f85 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b3a32e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3aadbc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 2025.09.09 14:29:01.457012 [ 7694 ] {8ca8acf6-2ea5-4c63-ab35-52eff57ff86f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45152) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:29:01.458728 [ 7694 ] {8ca8acf6-2ea5-4c63-ab35-52eff57ff86f} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:29:03.981777 [ 7701 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:04.663856 [ 7701 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:05.718086 [ 3618 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9a965849-da2f-426a-8ede-2051c1b8090e::202509_1_35_7}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:29:06.014603 [ 7808 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:07.227978 [ 7808 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:08.505962 [ 7738 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:09.253901 [ 7737 ] {fc15251e-9413-4163-b917-77b23602895a} executeQuery: Code: 57. DB::Exception: Table test_li9q3zuz.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49298) (comment: 00163_column_oriented_formats.sh) (in query: CREATE TABLE 00163_column_oriented(ClientEventTime DateTime('Asia/Dubai'), MobilePhoneModel String, ClientIP6 FixedString(16)) ENGINE=File(Arrow)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:29:09.256722 [ 7737 ] {fc15251e-9413-4163-b917-77b23602895a} TCPHandler: Code: 57. DB::Exception: Table test_li9q3zuz.`00163_column_oriented` 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:29:09.280539 [ 7808 ] {8bf41964-ece2-45d9-9fd6-664ed5c6e548} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49250) (comment: 00074_full_join.sql) (in query: SELECT CounterID, hits, visits FROM ( SELECT (CounterID % 100000) AS CounterID, count() AS hits FROM test.hits GROUP BY CounterID ) ANY FULL OUTER JOIN ( SELECT (CounterID % 100000) AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0 ) USING CounterID WHERE hits = 0 OR visits = 0 ORDER BY hits + visits * 10 DESC, CounterID ASC 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b86e6aa 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) @ 0x000000003b84c61a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b84d312 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b86c7f1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322aeb8f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000032293e34 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be4ca7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 2025.09.09 14:29:09.284079 [ 7808 ] {8bf41964-ece2-45d9-9fd6-664ed5c6e548} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b86e6aa 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) @ 0x000000003b84c61a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b84d312 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b86c7f1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322aeb8f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000032293e34 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be4ca7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 2025.09.09 14:29:09.771487 [ 7808 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:09.975846 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {22b0a30e-8738-451d-9c67-584e1807201a::202509_1_31_6}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:29:10.999377 [ 4621 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:11.446441 [ 7808 ] {e13cc98d-243c-4e58-83e9-9631f74a247f} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49332) (comment: 00163_column_oriented_formats.sh) (in query: INSERT INTO 00163_column_oriented SELECT ClientEventTime, MobilePhoneModel, ClientIP6 FROM test.hits ORDER BY ClientEventTime, MobilePhoneModel, ClientIP6 LIMIT 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000038332697 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&) @ 0x000000003ba7828f 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*) @ 0x0000000034b98bc1 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&) @ 0x0000000034b9bbcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba2360 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:29:11.449358 [ 7808 ] {e13cc98d-243c-4e58-83e9-9631f74a247f} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000038332697 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&) @ 0x000000003ba7828f 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*) @ 0x0000000034b98bc1 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&) @ 0x0000000034b9bbcf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba2360 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:29:12.423308 [ 7627 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:13.617030 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:14.792592 [ 7627 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:14.953063 [ 4134 ] {ae34db43-db8f-4043-a970-bf58d2000efa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49442) (comment: 00043_any_left_join.sql) (in query: SELECT EventDate, count() AS hits, any(visits) FROM test.hits ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate GROUP BY EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:29:14.980182 [ 4134 ] {ae34db43-db8f-4043-a970-bf58d2000efa} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:29:15.997957 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:17.192417 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:18.323941 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:19.571212 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:20.800054 [ 7627 ] {15d09fdb-1775-43b4-bd34-121376b8d8f7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38574) (comment: 00163_column_oriented_formats.sh) (in query: DROP DATABASE IF EXISTS test_li9q3zuz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:29:20.802214 [ 7627 ] {15d09fdb-1775-43b4-bd34-121376b8d8f7} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:29:21.021763 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:22.248476 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:22.850027 [ 7645 ] {208aee16-c5fa-4d55-8ef2-24698ee9b9a6} 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.10505.altinitytest (altinity build)) (from [::1]:59428) (comment: 00174_distinct_in_order.sql) (in query: insert into distinct_in_order select distinct CounterID, EventDate from test.hits order by CounterID, EventDate settings optimize_distinct_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./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*) @ 0x000000003ae7acd9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:29:22.854396 [ 7645 ] {208aee16-c5fa-4d55-8ef2-24698ee9b9a6} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./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*) @ 0x000000003ae7acd9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:29:23.438466 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:24.674257 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:25.941754 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:27.091880 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:28.245966 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:29.403123 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:30.535169 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:31.474358 [ 7641 ] {3348bb10-76b3-445b-a982-ad3542f7b3e7} 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.10505.altinitytest (altinity build)) (from [::1]:33336) (comment: 00081_group_by_without_key_and_totals.sql) (in query: SELECT 1 AS k, count() AS c FROM test.hits WHERE CounterID = 1704509 GROUP BY k WITH TOTALS SETTINGS totals_mode = 'after_having_inclusive', 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:29:31.477114 [ 7641 ] {3348bb10-76b3-445b-a982-ad3542f7b3e7} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:29:31.783685 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:33.019745 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:34.166950 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:35.291249 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:36.404566 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:37.678152 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:38.842032 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:40.121427 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:41.185310 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:42.297305 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:43.513920 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:44.689651 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:45.855333 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:46.932664 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:48.081498 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:49.230279 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:50.328601 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:51.418860 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:52.528620 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:53.638798 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:54.801273 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:55.881766 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:57.035216 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:58.162785 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:29:59.247523 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:00.597097 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:01.776580 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:02.842763 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:03.922875 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:05.121647 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:06.199516 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:07.313677 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:08.392225 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:09.485281 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:10.542320 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:11.673295 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:12.904248 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:14.025906 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:15.125959 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:16.294875 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:17.438014 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:18.549741 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:19.849239 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:21.179447 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:22.293907 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:23.503820 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:24.714331 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:25.891556 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:27.149336 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:28.346346 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:28.993482 [ 3623 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {82a03bbc-c240-4760-ac41-7d5c29a949ce::202509_1_40_8}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:30:29.465078 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:30.572326 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:31.417749 [ 7641 ] {6e4ff435-72b4-4c86-9bc5-c2956a1092cf} executeQuery: Code: 162. DB::Exception: Too deep subqueries. Maximum: 1. (TOO_DEEP_SUBQUERIES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52350) (comment: 02379_analyzer_subquery_depth.sql) (in query: SELECT (SELECT a FROM (SELECT 1 AS a)) SETTINGS max_subquery_depth = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7df54a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5257: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033434c49 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 29. ? @ 0x00007f550c19fac3 30. ? @ 0x00007f550c231850 2025.09.09 14:30:31.419518 [ 7641 ] {6e4ff435-72b4-4c86-9bc5-c2956a1092cf} TCPHandler: Code: 162. DB::Exception: Too deep subqueries. Maximum: 1. (TOO_DEEP_SUBQUERIES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7df54a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5257: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033434c49 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e4fc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000334460ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 29. ? @ 0x00007f550c19fac3 30. ? @ 0x00007f550c231850 2025.09.09 14:30:31.655073 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:32.833851 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:33.897839 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:35.015451 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:36.153515 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:37.360312 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:38.477496 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:39.548930 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:39.671232 [ 7641 ] {e7b57703-2bae-41ef-bd54-7bbda13b4fc7} executeQuery: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52370) (comment: 01289_min_execution_speed_not_too_early.sql) (in query: SET max_execution_time = 100, timeout_before_checking_execution_speed = 100, max_execution_speed = 1000000, max_threads = 1, max_block_size = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a0dcd 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159d74f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:39.673709 [ 7641 ] {e7b57703-2bae-41ef-bd54-7bbda13b4fc7} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a0dcd 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159d74f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:40.672367 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:41.770979 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:42.818920 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:43.864990 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:45.053337 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:46.183264 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:47.315457 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:48.516666 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:49.663788 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:50.886793 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:52.060539 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:52.651501 [ 3626 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {71093a84-ebed-448d-becc-536d0264ae9e::202509_66_86_4}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:30:53.252090 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:54.482604 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:55.872101 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:57.340506 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:58.549729 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:30:59.108520 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {735d8f76-3afe-45b6-b2c9-e3d138f09c35::202509_1_34_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009cb0d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x00000000200978df 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7e39f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011a21f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3aa5f2 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a73f4 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:30:59.810840 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:01.229484 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:02.505862 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:03.918933 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:05.257627 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:06.475661 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:07.801189 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:09.259972 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:10.602530 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:12.010346 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:13.405796 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:14.855626 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:16.566811 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:17.999034 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:19.775163 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:20.370060 [ 7641 ] {ce5415b5-7ef6-4714-bf71-9d5cf3c24c93} executeQuery: Code: 475. DB::Exception: Sort FILL TO expression must be constant with numeric type. Actual '2024-02-17'. In scope SELECT * FROM users ORDER BY date ASC WITH FILL TO '2024-02-17' STEP toIntervalHour(1). (INVALID_WITH_FILL_EXPRESSION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38880) (comment: 03248_with_fill_string_crash.sql) (in query: SELECT * FROM users ORDER BY date WITH FILL TO '2024-02-17' STEP toIntervalHour(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3997: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d77a0 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342ff64 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:31:20.371743 [ 7641 ] {ce5415b5-7ef6-4714-bf71-9d5cf3c24c93} TCPHandler: Code: 475. DB::Exception: Sort FILL TO expression must be constant with numeric type. Actual '2024-02-17'. In scope SELECT * FROM users ORDER BY date ASC WITH FILL TO '2024-02-17' STEP toIntervalHour(1). (INVALID_WITH_FILL_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3997: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d77a0 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342ff64 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:31:21.211637 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:22.815105 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:24.271220 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:24.816063 [ 4035 ] {} test_3.visits (a748ab4f-11eb-44d3-90b8-84e9919add16): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 14:31:25.671263 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:26.907653 [ 4035 ] {} DatabaseCatalog: Cannot drop table test_3.visits (a748ab4f-11eb-44d3-90b8-84e9919add16). 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000003972dea1 8. ./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>*) @ 0x0000000039726c72 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2997: DB::MergeTreeData::dropAllData() @ 0x000000003973d3aa 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2d4ad3 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339c1122 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339e1be3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303f218c 14. ./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()() @ 0x00000000303f1f6d 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b6d3d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f466e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:27.116253 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:28.633098 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:29.739877 [ 3622 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {735d8f76-3afe-45b6-b2c9-e3d138f09c35::202509_1_38_8}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:30.316541 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:32.068663 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:32.997663 [ 3465 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339bf518 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339c056e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339e149f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199e372 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a9693 12. ./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*) @ 0x00000000319ab32f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 15. ? @ 0x00007f550c19fac3 16. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:33.569095 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:34.878275 [ 7641 ] {337d9564-5dba-4f68-ab18-0b24860d0985} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40474) (comment: 02103_sql_user_defined_functions_composition.sql) (in query: SELECT 02103_test_function_with_nested_function_arg(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:31:34.883141 [ 7641 ] {337d9564-5dba-4f68-ab18-0b24860d0985} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:31:35.107774 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:36.418920 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:37.653132 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:37.719877 [ 4134 ] {100108a8-35a8-4599-a378-11ef7010a3bb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54126) (in query: select 1 where 'MUTATE_PART' not in (select type from system.replication_queue where database='test_3' and table='mut') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:31:37.724608 [ 4134 ] {100108a8-35a8-4599-a378-11ef7010a3bb} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:38.652920 [ 4134 ] {b6c7c191-4226-4a37-b03e-5a033a32042c} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54126) (in query: select 1 where 'MUTATE_PART' not in (select type from system.replication_queue where database='test_3' and table='mut') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:31:38.658188 [ 4134 ] {b6c7c191-4226-4a37-b03e-5a033a32042c} DynamicQueryHandler: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:38.743966 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:39.629825 [ 4134 ] {95466a6f-1dec-4d7a-8c0b-98b9fde563b0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54126) (in query: select 1 where 'MUTATE_PART' not in (select type from system.replication_queue where database='test_3' and table='mut') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b398dc0 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003aed9597 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:39.636119 [ 4134 ] {95466a6f-1dec-4d7a-8c0b-98b9fde563b0} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b398dc0 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003aed9597 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:39.879713 [ 4134 ] {e44ce53f-605f-4a6f-a461-742fef75d166} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54126) (in query: select 1 where 'MUTATE_PART' not in (select type from system.replication_queue where database='test_3' and table='mut') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:31:39.896475 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:39.977066 [ 4134 ] {e44ce53f-605f-4a6f-a461-742fef75d166} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:41.063868 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:41.238764 [ 4134 ] {8777d50e-c0f5-4ce3-be54-78cc7a3f0ed6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54126) (in query: select 1 where 'MUTATE_PART' not in (select type from system.replication_queue where database='test_3' and table='mut') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:31:41.243693 [ 4134 ] {8777d50e-c0f5-4ce3-be54-78cc7a3f0ed6} DynamicQueryHandler: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 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&)>) @ 0x00000000358b9e13 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:42.232447 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:43.239530 [ 4134 ] {650f5be7-92f2-48c7-bcc0-02f3dfefa544} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54126) (in query: select * from system.replication_queue where database='test_3' and table='mut' and type='ALTER_METADATA' ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:31:43.243830 [ 4134 ] {650f5be7-92f2-48c7-bcc0-02f3dfefa544} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:43.484464 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:44.250874 [ 4134 ] {61953bf7-f3e6-4cbe-a441-70320d1e0d8f} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54126) (in query: select * from system.replication_queue where database='test_3' and table='mut' and type='ALTER_METADATA' ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3a05c8 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aed9272 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 15. ./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&)>) @ 0x00000000358b9e13 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:31:44.256054 [ 4134 ] {61953bf7-f3e6-4cbe-a441-70320d1e0d8f} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3a05c8 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aed9272 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 15. ./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&)>) @ 0x00000000358b9e13 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:44.582574 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:45.730835 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:45.778292 [ 4134 ] {8eb83201-d100-4dae-9632-12883b2a0bed} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54126) (in query: select * from system.replication_queue where database='test_3' and table='mut' and type='ALTER_METADATA' ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b398dc0 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003aed9597 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 15. ./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&)>) @ 0x00000000358b9e13 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:31:45.787041 [ 4134 ] {8eb83201-d100-4dae-9632-12883b2a0bed} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b398dc0 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003aed9597 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 15. ./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&)>) @ 0x00000000358b9e13 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:46.638546 [ 4134 ] {16dd2efd-bb8f-4665-95c0-3b52fe0e5348} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54126) (in query: select * from system.replication_queue where database='test_3' and table='mut' and type='ALTER_METADATA' ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:31:46.642749 [ 4134 ] {16dd2efd-bb8f-4665-95c0-3b52fe0e5348} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:31:46.852211 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:48.051650 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:48.056265 [ 3622 ] {2baefedb-979a-4dda-bb93-24df90407d5a::all_0_0_0_1} MutateTask: Ignoring column k from part all_0_0_0 with metadata version 0 because there is no such column in table test_3.mut (2baefedb-979a-4dda-bb93-24df90407d5a) with metadata version 1. Assuming the column was dropped 2025.09.09 14:31:49.189131 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:50.406051 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:50.580385 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} mysqlxx::Pool: Failed to connect to MySQL (conv_main@127.0.0.1:3456 as user metrika): mysqlxx::ConnectionFailed 2025.09.09 14:31:50.580923 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} Application: Connection to conv_main@127.0.0.1:3456 as user metrika failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0) 2025.09.09 14:31:50.581144 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} Application: Connection to mysql failed 1 times 2025.09.09 14:31:50.581685 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} mysqlxx::Pool: Failed to connect to MySQL (conv_main@127.0.0.1:3456 as user metrika): mysqlxx::ConnectionFailed 2025.09.09 14:31:50.581844 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} Application: Connection to conv_main@127.0.0.1:3456 as user metrika failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0) 2025.09.09 14:31:50.581908 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} Application: Connection to mysql failed 2 times 2025.09.09 14:31:50.582424 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} mysqlxx::Pool: Failed to connect to MySQL (conv_main@127.0.0.1:3456 as user metrika): mysqlxx::ConnectionFailed 2025.09.09 14:31:50.582575 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} Application: Connection to conv_main@127.0.0.1:3456 as user metrika failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0) 2025.09.09 14:31:50.582645 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} Application: Connection to mysql failed 3 times 2025.09.09 14:31:51.538597 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:52.650939 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:52.740339 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} executeQuery: Code: 501. DB::Exception: Cannot create MySQL database, because Code: 279. DB::Exception: Connections to mysql failed: conv_main@127.0.0.1:3456 as user metrika, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x0000000040358ba9 5. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::fetchTablesWithModificationTime(std::shared_ptr) const @ 0x0000000032da599d 6. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::fetchTablesIntoLocalCache(std::shared_ptr) const @ 0x0000000032d9f132 7. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::empty() const @ 0x0000000032d9df28 8. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::DatabaseMySQL(std::shared_ptr, String const&, String const&, DB::ASTStorage const*, String const&, std::unique_ptr>, mysqlxx::PoolWithFailover&&, bool) @ 0x0000000032d9d165 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>, mysqlxx::PoolWithFailover, bool const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>&&, mysqlxx::PoolWithFailover&&, bool const&) @ 0x0000000032dbda7f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000032db5d59 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032908bab 12. ./build_docker/./src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x00000000329072d3 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488812a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)). (CANNOT_CREATE_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33846) (comment: 01114_mysql_database_engine_segfault.sql) (in query: CREATE DATABASE conv_main ENGINE = MySQL('127.0.0.1:3456', conv_main, 'metrika', '[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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:584: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000032db6f00 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032908bab 6. ./build_docker/./src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x00000000329072d3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488812a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:52.742084 [ 7645 ] {16b6236e-be5b-4fe6-8fbd-016d38b357fa} TCPHandler: Code: 501. DB::Exception: Cannot create MySQL database, because Code: 279. DB::Exception: Connections to mysql failed: conv_main@127.0.0.1:3456 as user metrika, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x0000000040358ba9 5. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::fetchTablesWithModificationTime(std::shared_ptr) const @ 0x0000000032da599d 6. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::fetchTablesIntoLocalCache(std::shared_ptr) const @ 0x0000000032d9f132 7. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::empty() const @ 0x0000000032d9df28 8. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::DatabaseMySQL(std::shared_ptr, String const&, String const&, DB::ASTStorage const*, String const&, std::unique_ptr>, mysqlxx::PoolWithFailover&&, bool) @ 0x0000000032d9d165 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>, mysqlxx::PoolWithFailover, bool const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>&&, mysqlxx::PoolWithFailover&&, bool const&) @ 0x0000000032dbda7f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000032db5d59 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032908bab 12. ./build_docker/./src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x00000000329072d3 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488812a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)). (CANNOT_CREATE_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:584: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000032db6f00 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032908bab 6. ./build_docker/./src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x00000000329072d3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003488812a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:54.090378 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:55.252730 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:56.453619 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:57.622303 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:58.837226 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:31:59.978753 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:01.169172 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:02.378093 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:03.589669 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:04.794362 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:05.958880 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:07.162355 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:08.331561 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:09.549710 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:10.729592 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:11.987159 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:12.149552 [ 3616 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {71093a84-ebed-448d-becc-536d0264ae9e::202509_91_106_3}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:32:13.159121 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:14.290222 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:15.473803 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:15.901571 [ 3613 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {58feac31-2113-4d4b-a28d-44e8469283aa::1_1_10_1}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:32:16.594608 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:16.845227 [ 7641 ] {d5fafb89-6c63-4a89-b655-2cbc6f428e02} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48024) (comment: 01915_merge_prewhere_virtual_column_rand_chao_wang.sql) (in query: CREATE TABLE abc (`f1` String, `f2` String) ENGINE = MergeTree ORDER BY f1 SETTINGS index_granularity = 16508, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.892076313495636, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 282799224, compact_parts_max_bytes_to_buffer = 334823629, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 2962165, merge_max_block_size = 22817, 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 = 17302290, concurrent_part_removal_threshold = 22, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 42421, primary_key_compress_block_size = 17425), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:32:16.846419 [ 7641 ] {d5fafb89-6c63-4a89-b655-2cbc6f428e02} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:32:17.761777 [ 12541 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:19.143855 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:20.197103 [ 7641 ] {3b9b752b-febb-4a13-9301-6e32e198a7d2} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48058) (comment: 02490_replacing_merge_tree_is_deleted_column.sql) (in query: CREATE TABLE test (`uid` String, `version` UInt32, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(version) ORDER BY uid SETTINGS clean_deleted_rows = 'Always', allow_experimental_replacing_merge_with_cleanup = 1, index_granularity = 56891, min_bytes_for_wide_part = 0, 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 = 279447176, compact_parts_max_bytes_to_buffer = 526201246, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10835374, merge_max_block_size = 15649, old_parts_lifetime = 282., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 74445, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1109030844, index_granularity_bytes = 8577951, concurrent_part_removal_threshold = 92, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 85148, primary_key_compress_block_size = 55607), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:32:20.198658 [ 7641 ] {3b9b752b-febb-4a13-9301-6e32e198a7d2} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:32:20.428243 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:21.692367 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:22.891335 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:24.270548 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:25.570942 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:26.761042 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:27.957074 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:29.361423 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:30.629882 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:31.785233 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:32.986518 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:34.103640 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:34.901568 [ 12541 ] {a7d26001-8f8c-4e1a-82d6-4d6f48eb7ac8} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46966) (comment: 01710_projection_in_index.sql) (in query: CREATE TABLE test (`name` String, `time` Int64) ENGINE = MergeTree ORDER BY time SETTINGS index_granularity = 61139, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 75, min_bytes_for_full_part_storage = 435301962, compact_parts_max_bytes_to_buffer = 112250905, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 6493398, merge_max_block_size = 17129, old_parts_lifetime = 214., prefer_fetch_merged_part_size_threshold = 9241671017, vertical_merge_algorithm_min_rows_to_activate = 469939, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 680067, concurrent_part_removal_threshold = 84, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 26609, primary_key_compress_block_size = 47885), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:32:34.903464 [ 12541 ] {a7d26001-8f8c-4e1a-82d6-4d6f48eb7ac8} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:32:35.214560 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:36.357285 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:37.580216 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:38.783037 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:39.986060 [ 12541 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:41.323324 [ 12541 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:42.721228 [ 12541 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:44.082483 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:45.325631 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:46.590064 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:47.869107 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:49.030756 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:50.340648 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:51.856087 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:53.246345 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:53.397454 [ 3612 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9a965849-da2f-426a-8ede-2051c1b8090e::202509_1_65_13}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:32:54.483412 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:55.716687 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:57.129141 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:58.337252 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:32:59.834481 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:01.142030 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:02.401893 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:03.801087 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:05.144937 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:06.517761 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:07.875772 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:09.241137 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:10.724961 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:12.017762 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:13.174042 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:14.311672 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:15.436136 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:16.661741 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:17.850498 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:19.182010 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:20.529649 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:21.934589 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:23.184588 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:24.609292 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:25.862224 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:27.241131 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:28.486323 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:29.639816 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:30.635281 [ 7645 ] {1cef4aa3-4e8b-4445-85b8-672fa63c9c26} 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.10505.altinitytest (altinity build)) (from [::1]:35790) (comment: 02382_join_and_filtering_set.sql) (in query: SELECT count() FROM t1 JOIN t2 ON t1.x = t2.x WHERE t1.x % 2 == 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d2b850 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfb07da 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c05ddb3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfbccf3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21ce0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 26. ? @ 0x00007f550c19fac3 27. ? @ 0x00007f550c231850 2025.09.09 14:33:30.643055 [ 7645 ] {1cef4aa3-4e8b-4445-85b8-672fa63c9c26} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d2b850 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfb07da 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c05ddb3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfbccf3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21ce0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 26. ? @ 0x00007f550c19fac3 27. ? @ 0x00007f550c231850 2025.09.09 14:33:30.945096 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:32.112099 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:33.459350 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:33.701566 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:34.682597 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:34.718342 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:35.889719 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:35.957423 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:37.161950 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:37.512586 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:38.398467 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:38.680180 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:39.695290 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:39.943377 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:40.937114 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:41.247478 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:42.296413 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:42.484380 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:43.584071 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:43.698173 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:44.903897 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:45.181970 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:46.188564 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:46.397773 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:47.409058 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:47.665112 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:48.641104 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:49.003112 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:49.925488 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:50.435546 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:51.370542 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:51.750366 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:52.640699 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:52.968000 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:53.856664 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:54.244049 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:55.203838 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:55.553005 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:56.458245 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:56.797350 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:57.666349 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:57.986307 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:58.826626 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:33:59.097725 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:00.047905 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:00.307394 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:01.253243 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:01.542869 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:02.562899 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:02.662276 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:03.735027 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:03.824397 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:04.923570 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:04.924527 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:06.179407 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:06.259100 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:07.344157 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:07.706446 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:08.637750 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:09.058587 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:09.867646 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:10.206371 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:11.176374 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:11.436597 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:12.373017 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:12.606059 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:13.544254 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:13.763957 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:14.760054 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:15.049962 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:15.914703 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:16.323912 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:17.270002 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:17.624308 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:18.419611 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:18.704276 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:19.565385 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:20.094723 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:20.803985 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:21.281822 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:22.038007 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:22.445233 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:23.153076 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:23.546995 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:24.330199 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:24.662134 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:25.531362 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:25.788069 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:26.619178 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:26.921554 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:27.838800 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:28.085615 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:28.989344 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:29.295404 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:30.125162 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:30.407943 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:31.281802 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:31.621651 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:32.482301 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:32.737122 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:33.602245 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:33.906923 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:34.799582 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:35.043588 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:35.992930 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:36.131413 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:37.277597 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:37.277906 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:38.421540 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:38.513917 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:39.645430 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:39.712197 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:40.777269 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:40.837084 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:41.899835 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:41.958754 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:43.123862 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:43.138569 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:44.227303 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:44.390144 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:45.334146 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:45.645765 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:46.459198 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:46.756081 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:47.647080 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:47.929564 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:48.816527 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:49.069809 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:49.414494 [ 3615 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2e8e608b-0227-42c6-a4f2-8bcbec2cc77e::202509_1_61_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:34:49.894155 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:50.163917 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:51.030089 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:51.247907 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:52.342646 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:52.355322 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:53.470040 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:53.706746 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:54.630849 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:54.832038 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:55.738489 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:56.038799 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:57.136492 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:57.391285 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:58.305044 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:58.482695 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:59.432702 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:34:59.650070 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:00.665479 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:00.803914 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:01.932102 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:02.054429 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:03.076101 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:03.242604 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:04.299338 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:04.381746 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:05.405118 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:05.512872 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:06.564421 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:06.696982 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:07.670198 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:07.839087 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:08.863210 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:08.897751 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:09.965185 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:10.064550 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:11.094285 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:11.219596 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:12.226814 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:12.432502 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:13.426813 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:13.619962 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:14.593730 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:14.814554 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:15.778277 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:15.995713 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:16.939215 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:17.149474 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:18.061018 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:18.297253 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:19.213842 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:19.672506 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:20.424722 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:20.863466 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:21.558077 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:22.047817 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:22.675402 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:23.156281 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:23.810223 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:24.269048 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:25.087203 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:25.671541 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:26.444571 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:26.845111 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:27.664472 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:28.019397 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:28.844912 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:29.263495 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:30.243241 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:30.408620 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:31.471882 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:31.621927 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:32.698822 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:32.973147 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:33.905292 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:34.392120 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:35.329081 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:35.613088 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:36.513114 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:36.862453 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:37.713338 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:38.127425 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:38.981429 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:39.458863 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:40.335442 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:40.752629 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:41.651979 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:41.950014 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:43.044217 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:43.324507 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:44.227873 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:44.543161 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:45.469845 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:45.810175 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:46.907649 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:47.115011 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:47.981963 [ 3613 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {099aa52d-ff08-48bf-87ed-79cf97f266be::202509_1_84_43}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:35:48.329246 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:48.367701 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:49.551883 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:49.567664 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:50.917133 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:50.934820 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:52.157735 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:52.218855 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:53.535117 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:53.548363 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:54.721819 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:54.733076 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:55.945686 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:55.981745 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:57.358424 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:57.407576 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:58.638173 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:35:58.821205 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:00.150226 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:00.234355 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:00.267615 [ 3617 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {71093a84-ebed-448d-becc-536d0264ae9e::202509_91_161_14}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:36:01.445967 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:01.567284 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:02.749440 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:02.980278 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:04.083710 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:04.216243 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:05.397891 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:05.505421 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:06.911960 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:06.914830 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:08.159101 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:08.169798 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:09.366366 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:09.400212 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:10.620527 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:10.622752 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:11.831293 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:11.927614 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:13.183129 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:13.341773 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:14.436085 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:14.647303 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:15.673049 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:15.947851 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:16.866898 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:17.181772 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:18.095770 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:18.605851 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:19.371809 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:20.072732 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:20.757920 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:21.411336 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:22.101694 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:22.698589 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:23.475965 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:24.000270 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:24.814125 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:25.291949 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:26.104674 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:26.830129 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:27.285593 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:28.255411 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:28.689891 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:29.702837 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:30.053729 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:31.299818 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:31.299822 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:32.573704 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:32.632933 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:33.965660 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:34.145732 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:35.193694 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:35.461645 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:36.419286 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:36.827260 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:37.655207 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:38.096265 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:39.037842 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:39.348355 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:40.353655 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:40.721524 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:41.625029 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:41.990193 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:42.955124 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:43.222065 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:44.192415 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:44.467917 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:45.578632 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:45.792606 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:46.992190 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:47.049985 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:48.304092 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:48.386283 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:49.725789 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:49.927901 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:51.182405 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:51.552181 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:52.585177 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:52.897988 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:53.905472 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:54.176152 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:55.266096 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:55.582092 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:56.510486 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:56.924928 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:57.892150 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:58.215556 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:59.270390 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:36:59.515000 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:00.605081 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:00.855186 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:01.993920 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:02.227433 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:03.467611 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:03.862685 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:05.002427 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:05.305291 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:06.562510 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:06.706141 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:07.894665 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:08.145367 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:09.340069 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:09.766494 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:10.798095 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:11.242725 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:12.193555 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:12.596083 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:13.614153 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:14.022579 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:14.949406 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:15.329890 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:16.230367 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:16.669686 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:17.545891 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:18.040645 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:18.913244 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:19.365163 [ 3612 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9a965849-da2f-426a-8ede-2051c1b8090e::202509_1_100_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:37:19.482634 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:19.888627 [ 3617 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9a965849-da2f-426a-8ede-2051c1b8090e::202509_1_100_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:37:20.224986 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:20.804156 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:21.626828 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:22.217426 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:22.972844 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:23.524385 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:24.296337 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:24.872211 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:25.563408 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:26.231489 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:27.041949 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:27.500280 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:28.273578 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:28.738595 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:29.477718 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:30.070760 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:30.686094 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:31.412508 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:31.966290 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:32.706658 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:33.261741 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:33.988352 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:34.483828 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:35.533574 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:35.801571 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:37.051759 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:37.290160 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:38.522117 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:38.749494 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:39.910855 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:40.091222 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:41.176351 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:41.380365 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:42.449057 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:42.642321 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:43.654302 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:43.838116 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:44.937693 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:45.165903 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:46.302398 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:46.615122 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:47.566230 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:47.961828 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:49.136727 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:49.326178 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:50.568062 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:50.643961 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:51.866156 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:52.048986 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:53.171808 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:53.406273 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:54.383784 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:54.866282 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:55.719548 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:56.173578 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:57.120537 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:57.436726 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:58.430739 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:58.840501 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:37:59.740527 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:00.070562 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:01.068431 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:01.345732 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:02.355072 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:02.702064 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:03.045856 [ 7645 ] {50986b7c-d9c0-43ad-8bc8-0d092c1fa355} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54750) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 8439835;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:38:03.049878 [ 7645 ] {50986b7c-d9c0-43ad-8bc8-0d092c1fa355} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:38:03.617380 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:03.857298 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:04.941629 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:05.256982 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:06.227085 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:06.484188 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:07.541637 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:07.695042 [ 14984 ] {f6ddc632-eec2-4992-a7a1-c4c3191ee0c8} executeQuery: Code: 57. DB::Exception: Table test.join already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39426) (comment: 00065_loyalty_with_storage_join.sql) (in query: CREATE TABLE join (UserID UInt64, loyalty Int8) ENGINE = Join(SEMI, LEFT, UserID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:38:07.697951 [ 14984 ] {f6ddc632-eec2-4992-a7a1-c4c3191ee0c8} TCPHandler: Code: 57. DB::Exception: Table test.join 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:38:07.709734 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:08.946790 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:09.284236 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:10.411644 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:10.693172 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:11.790696 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:12.023699 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:13.065609 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:13.346395 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:14.567322 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:14.618571 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:14.669150 [ 7645 ] {647601d4-deb5-42ed-8eb2-df324d97de14} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39592) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:38:14.671449 [ 7645 ] {647601d4-deb5-42ed-8eb2-df324d97de14} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:38:16.126971 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:16.310332 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:17.471410 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:17.727677 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:18.816148 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:19.085404 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:20.112712 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:20.386519 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:21.480541 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:21.655417 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:22.882109 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:22.977190 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:24.166977 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:24.224126 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:25.401055 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:25.439597 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:26.572367 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:26.665983 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:27.886049 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:27.989917 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:29.224804 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:29.325471 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:30.427011 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:30.624305 [ 14984 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:31.735677 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:31.837560 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:32.994230 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:33.107724 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:34.308978 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:34.364988 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:35.548282 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:35.660131 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:36.768524 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:36.997139 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:38.007104 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:38.219478 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:39.118724 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:39.431204 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:40.294992 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:40.599030 [ 7641 ] {4aa125ad-2f56-4800-8e9f-71183016db55} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56366) (comment: 00004_top_counters.sql) (in query: SELECT CounterID, count() AS c FROM test.hits GROUP BY CounterID 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:38:40.603864 [ 7641 ] {4aa125ad-2f56-4800-8e9f-71183016db55} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:38:40.722369 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:41.478267 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:41.760098 [ 7641 ] {891d28c8-d3c9-44e6-81a2-e8cd5e96cf62} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56408) (comment: 00036_aggregate_hashed.sql) (in query: SELECT SearchEngineID AS k1, SearchPhrase AS k2, count() AS c FROM test.hits GROUP BY k1, k2 ORDER BY c DESC, k1, k2 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:38:41.851872 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:41.856025 [ 7641 ] {891d28c8-d3c9-44e6-81a2-e8cd5e96cf62} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:38:42.612479 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:43.066196 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:43.819612 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:44.227694 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:45.140072 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:45.379500 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:46.315645 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:46.552132 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:47.503264 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:47.763111 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:48.690148 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:48.960027 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:49.950022 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:50.175569 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:50.453740 [ 7641 ] {5607974e-d824-47a2-8df0-2ade0c11b9c1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56846) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime LIMIT 10 FORMAT Null SETTINGS filesystem_cache_reserve_space_wait_lock_timeout_milliseconds=2000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:38:50.468120 [ 7641 ] {5607974e-d824-47a2-8df0-2ade0c11b9c1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:38:51.090284 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:51.424818 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:52.258542 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:52.622505 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:53.374804 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:53.705346 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:54.522392 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:54.876602 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:55.630274 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:56.081329 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:56.587478 [ 7641 ] {27e1635c-2c84-4722-8a05-34777449b4dc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56892) (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_26851' 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a43d25 7. ./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) @ 0x000000003bf04769 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf16ef9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1c8e0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:38:56.590486 [ 7641 ] {27e1635c-2c84-4722-8a05-34777449b4dc} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dfbb4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a43d25 7. ./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) @ 0x000000003bf04769 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf16ef9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1c8e0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:38:56.856017 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:57.171847 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:57.926735 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:58.266196 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:59.133108 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:38:59.178758 [ 7645 ] {2ed60bc1-be7c-4d4c-8319-ba475d42041c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56196) (comment: 00150_quantiles_timing_precision.sql) (in query: SELECT CounterID, quantileTiming(0.5)(SendTiming) AS qt, least(30000, quantileExact(0.5)(SendTiming)) AS qe, count() AS c, round(abs(qt - qe) / greatest(qt, qe) AS diff, 3) AS rounded_diff FROM test.hits WHERE SendTiming != -1 GROUP BY CounterID HAVING diff != 0 ORDER BY diff DESC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:38:59.183537 [ 7645 ] {2ed60bc1-be7c-4d4c-8319-ba475d42041c} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:38:59.407964 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:00.071809 [ 7645 ] {f7cba828-39db-48ad-8cd6-64ce5181bf7d} 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.10505.altinitytest (altinity build)) (from [::1]:56234) (comment: 00083_array_filter.sql) (in query: SELECT sum(length(ParsedParams.Key1)) FROM test.hits WHERE notEmpty(ParsedParams.Key1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:39:00.075078 [ 7645 ] {f7cba828-39db-48ad-8cd6-64ce5181bf7d} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:39:00.217976 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:00.586867 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:01.328317 [ 7645 ] {e67cbfff-11ae-4e3a-86a9-e8f703fc251c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56240) (comment: 00009_uniq_distributed.sql) (in query: SELECT uniq(UserID), uniqIf(UserID, CounterID = 800784), uniqIf(FUniqID, RegionID = 213) FROM remote('127.0.0.{1,2}', 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:39:01.333289 [ 7645 ] {e67cbfff-11ae-4e3a-86a9-e8f703fc251c} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:39:01.708336 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:02.899146 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:03.998569 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:05.097505 [ 7645 ] {9db67c5d-4383-48dc-8b8d-ab9f538a0fd2} executeQuery: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (TYPE_MISMATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56262) (comment: 02864_statistics_bugs.sql) (in query: SELECT count(*) FROM bug_67742 WHERE a < '10.5';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4d3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c98b0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bfcad 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b50260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b06b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033245090 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000332401e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80fe28 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be11a9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5e711 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1a86e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d02a31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:39:05.100427 [ 7645 ] {9db67c5d-4383-48dc-8b8d-ab9f538a0fd2} TCPHandler: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4d3ad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357c98b0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357bfcad 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b50260 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b06b8c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000033245090 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000332401e3 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b80fe28 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003be11a9c 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c5e711 18. ./build_docker/./src/Planner/Planner.cpp:360: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d1a86e 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d02a31 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:39:05.153566 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:05.235887 [ 15427 ] {35320795-c5f1-4300-adcb-2320b487229a} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000012 */ CREATE TABLE test_11.parsing_with_names UUID 'e92f57a9-285a-49c3-b420-2d1d37841430' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:05.244463 [ 15427 ] {35320795-c5f1-4300-adcb-2320b487229a} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56304) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:05.247331 [ 15427 ] {35320795-c5f1-4300-adcb-2320b487229a} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:06.446794 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:07.193143 [ 3620 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bc0a1a75-a9c6-4ecc-9448-fa6d46e70b3a::202509_1_31_6}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:39:07.682510 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:07.952898 [ 7645 ] {55a789eb-38f0-4cbb-890b-2735589ca011} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60270) (comment: 03224_nested_json_merges_new_type_in_shared_data.sql) (in query: CREATE TABLE test (`json` JSON(max_dynamic_paths = 8)) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 3836, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 59, min_bytes_for_full_part_storage = 182346270, compact_parts_max_bytes_to_buffer = 367986130, compact_parts_max_granules_to_buffer = 33, compact_parts_merge_max_bytes_to_prefetch_part = 32376550, merge_max_block_size = 24389, 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 = 10602251856, index_granularity_bytes = 21956700, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 53692, primary_key_compress_block_size = 88573), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:07.955348 [ 7645 ] {55a789eb-38f0-4cbb-890b-2735589ca011} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:08.874953 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:09.355798 [ 15427 ] {2e5663f0-5194-420f-a97c-94c5b68bb646} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000014 */ CREATE TABLE test_11.parsing_with_names UUID '5b8d5885-6d63-4e33-aadb-5584a4ef67e0' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:09.364168 [ 15427 ] {2e5663f0-5194-420f-a97c-94c5b68bb646} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60304) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:09.366772 [ 15427 ] {2e5663f0-5194-420f-a97c-94c5b68bb646} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:09.962376 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:11.046922 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:12.124021 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:13.315605 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:13.404603 [ 15553 ] {64be7cbc-3600-44a5-ad60-c2058f1980d0} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000016 */ CREATE TABLE test_11.parsing_with_names UUID 'cffadcfa-39e6-49fa-82b7-031b45caf29e' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:13.507052 [ 15553 ] {64be7cbc-3600-44a5-ad60-c2058f1980d0} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60384) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:13.509574 [ 15553 ] {64be7cbc-3600-44a5-ad60-c2058f1980d0} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:14.478239 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:14.968334 [ 7645 ] {c0805b8f-a140-4433-a4bb-65e8cd3c4567} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60300) (comment: 02235_add_part_offset_virtual_column.sql) (in query: SELECT count(*) FROM t_1 WHERE _part_offset != order_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:39:14.973147 [ 7645 ] {c0805b8f-a140-4433-a4bb-65e8cd3c4567} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:39:15.689578 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:16.073204 [ 15553 ] {52cfea6a-6d3a-4a6d-a613-d1be66cb1e6b} executeQuery: Code: 57. DB::Exception: Table test_13.alter_ttl already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60446) (comment: 01070_alter_with_ttl.sql) (in query: create table alter_ttl(d Date, s String) engine = MergeTree order by d ttl d + interval 1 month;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:16.075695 [ 15553 ] {52cfea6a-6d3a-4a6d-a613-d1be66cb1e6b} TCPHandler: Code: 57. DB::Exception: Table test_13.alter_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:16.851010 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:17.259531 [ 15553 ] {a19bf897-4eb2-470e-b4e1-ead7bd5e2d25} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000018 */ CREATE TABLE test_11.parsing_with_names UUID '9a3f7bcf-b5f4-42a4-8178-810dba29cbf7' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:17.266395 [ 15553 ] {a19bf897-4eb2-470e-b4e1-ead7bd5e2d25} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47532) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:17.268620 [ 15553 ] {a19bf897-4eb2-470e-b4e1-ead7bd5e2d25} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:18.075494 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:19.143693 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:20.221973 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:20.861198 [ 15427 ] {5228275e-c3dc-45f6-afaa-265c44fb0b6d} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000020 */ CREATE TABLE test_11.parsing_with_names UUID '094dda23-f7b8-465e-a78f-03ec4826f0bc' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:20.867124 [ 15427 ] {5228275e-c3dc-45f6-afaa-265c44fb0b6d} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47594) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:20.869372 [ 15427 ] {5228275e-c3dc-45f6-afaa-265c44fb0b6d} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:21.289242 [ 3611 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {71093a84-ebed-448d-becc-536d0264ae9e::202509_91_211_24}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:39:21.419757 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:22.763438 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:23.500215 [ 15427 ] {51f7b510-7de4-4d77-a492-070704e08161} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47636) (comment: 02731_in_operator_with_one_size_tuple.sql) (in query: CREATE TABLE test (`report_date` Date, `sspid` UInt64) ENGINE = MergeTree PARTITION BY report_date ORDER BY report_date SETTINGS index_granularity = 10492, min_bytes_for_wide_part = 380995820, ratio_of_defaults_for_sparse_serialization = 1., 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 = 83238117, compact_parts_max_granules_to_buffer = 151, compact_parts_merge_max_bytes_to_prefetch_part = 5283296, merge_max_block_size = 11681, old_parts_lifetime = 480., 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 = 6097493302, index_granularity_bytes = 20159884, concurrent_part_removal_threshold = 85, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 41609, primary_key_compress_block_size = 55042), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:23.502291 [ 15427 ] {51f7b510-7de4-4d77-a492-070704e08161} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:23.875250 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:24.981418 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:26.061178 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:27.135812 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:27.962753 [ 7645 ] {c93343de-7630-4917-8362-766157e33678} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000024 */ CREATE TABLE test_11.parsing_with_names UUID 'b429765e-5fae-4852-81dc-01003fd0e9f0' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:27.969656 [ 7645 ] {c93343de-7630-4917-8362-766157e33678} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58030) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:27.972096 [ 7645 ] {c93343de-7630-4917-8362-766157e33678} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:28.280292 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:29.376650 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:30.462145 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:30.548278 [ 15553 ] {8efdc393-1b32-40f8-9d26-ed735c0c8079} executeQuery: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47658) (comment: 01289_min_execution_speed_not_too_early.sql) (in query: SET max_execution_time = 100, timeout_before_checking_execution_speed = 100, max_execution_speed = 1000000, max_threads = 1, max_block_size = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a0dcd 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159d74f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:30.550259 [ 15553 ] {8efdc393-1b32-40f8-9d26-ed735c0c8079} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a0dcd 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159d74f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:31.261703 [ 15427 ] {ad941755-94a2-4721-aa0f-d76b590efc5b} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000026 */ CREATE TABLE test_11.parsing_with_names UUID '206d4740-81d4-4f34-9fa7-1e133d05286d' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:31.269819 [ 15427 ] {ad941755-94a2-4721-aa0f-d76b590efc5b} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58162) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:31.272372 [ 15427 ] {ad941755-94a2-4721-aa0f-d76b590efc5b} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:31.631236 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:32.718371 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:33.492698 [ 15427 ] {145ec930-001a-4638-ac61-107e391990d5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58266) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT * FROM parsing_with_names;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:33.494603 [ 15427 ] {145ec930-001a-4638-ac61-107e391990d5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:33.786591 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:34.660255 [ 15427 ] {aaf8fd51-691e-486b-b6b2-3a4bd9e7948a} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000028 */ CREATE TABLE test_11.parsing_with_names UUID 'c1fd98d8-1184-491c-a9f4-ef8f3a1329aa' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:34.667700 [ 15427 ] {aaf8fd51-691e-486b-b6b2-3a4bd9e7948a} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58326) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:34.670185 [ 15427 ] {aaf8fd51-691e-486b-b6b2-3a4bd9e7948a} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:34.839205 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:35.544075 [ 15553 ] {b1478a3e-474d-42cd-838e-ff6877b222e3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58366) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactStringsEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:35.546525 [ 15553 ] {b1478a3e-474d-42cd-838e-ff6877b222e3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:35.919383 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:37.016200 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:38.126421 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:38.199133 [ 4134 ] {c2c376d0-4355-4d9a-97f4-cc06c08e992b} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000030 */ CREATE TABLE test_11.parsing_with_names UUID '31370cff-8031-4f9e-8452-41668ec4b480' (`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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:38.206378 [ 4134 ] {c2c376d0-4355-4d9a-97f4-cc06c08e992b} executeQuery: Code: 57. DB::Exception: Table test_11.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44730) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:38.208712 [ 4134 ] {c2c376d0-4355-4d9a-97f4-cc06c08e992b} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033956f1e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000003395022c 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032aceacd 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4a29c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c2364 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:39:39.393544 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:40.568339 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:41.747282 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:42.124063 [ 4134 ] {f3d3d8d2-f8f3-448f-a44c-67f69ad7693b} executeQuery: Code: 57. DB::Exception: Table test_xqjh5jlf.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44884) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:42.126838 [ 4134 ] {f3d3d8d2-f8f3-448f-a44c-67f69ad7693b} TCPHandler: Code: 57. DB::Exception: Table test_xqjh5jlf.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:42.850720 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:43.952727 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:45.098674 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:46.342097 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:47.400169 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:48.537840 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:48.863695 [ 4134 ] {2e1e39b9-e5ea-49d6-be8e-50e740b93ebf} executeQuery: Code: 57. DB::Exception: Table test_xqjh5jlf.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52554) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:48.865866 [ 4134 ] {2e1e39b9-e5ea-49d6-be8e-50e740b93ebf} TCPHandler: Code: 57. DB::Exception: Table test_xqjh5jlf.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:49.613040 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:50.715623 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:51.799860 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:53.005488 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:54.229751 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:55.379236 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:56.154951 [ 16153 ] {1c21eef8-ccfc-41be-9b97-461028c27489} executeQuery: Code: 57. DB::Exception: Table test_xqjh5jlf.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52744) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:56.157148 [ 16153 ] {1c21eef8-ccfc-41be-9b97-461028c27489} TCPHandler: Code: 57. DB::Exception: Table test_xqjh5jlf.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:39:56.730240 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:57.904136 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:39:59.000585 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:00.077944 [ 16153 ] {a1023c71-5e09-4644-8eca-69426ccc429f} executeQuery: Code: 57. DB::Exception: Table test_xqjh5jlf.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43204) (comment: 00167_parallel_parsing_with_names_and_types.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:40:00.080170 [ 16153 ] {a1023c71-5e09-4644-8eca-69426ccc429f} TCPHandler: Code: 57. DB::Exception: Table test_xqjh5jlf.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:40:00.157962 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:01.303761 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:02.469513 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:03.589197 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:03.992375 [ 15553 ] {f60ce092-fc6a-4e7e-90a0-b3e4a9274dfe} 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.10505.altinitytest (altinity build)) (from [::1]:52732) (comment: 02371_select_projection_normal_agg.sql) (in query: INSERT INTO video_log_result SELECT toStartOfHour(datetime) AS hour, sum(bytes), avg(duration) FROM video_log WHERE (toDate(hour) = '2022-07-22') AND (device_id = '100') --(device_id = '100') Make sure it's not good and doesn't go into prewhere. GROUP BY hour;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./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*) @ 0x000000003ae7acd9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:40:03.997102 [ 15553 ] {f60ce092-fc6a-4e7e-90a0-b3e4a9274dfe} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./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*) @ 0x000000003ae7acd9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:40:04.829863 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:06.085411 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:06.186379 [ 15553 ] {c40ec8b1-e398-4760-a827-b32d5d85f486} executeQuery: Code: 57. DB::Exception: Table test.join already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43340) (comment: 00065_loyalty_with_storage_join.sql) (in query: CREATE TABLE join (UserID UInt64, loyalty Int8) ENGINE = Join(SEMI, LEFT, UserID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:40:06.188586 [ 15553 ] {c40ec8b1-e398-4760-a827-b32d5d85f486} TCPHandler: Code: 57. DB::Exception: Table test.join 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:40:07.142148 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:08.302879 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:08.677447 [ 4134 ] {60439621-c9ff-4e36-8c3e-562c29711556} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44580) (comment: 00162_mmap_compression_none.sql) (in query: DROP DATABASE IF EXISTS test_a7o8kbs7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:40:08.679456 [ 4134 ] {60439621-c9ff-4e36-8c3e-562c29711556} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:40:08.697006 [ 7645 ] {db5cebc9-a5d3-4d5c-809d-edb54921982e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44582) (comment: 00162_mmap_compression_none.sql) (in query: DROP DATABASE IF EXISTS test_a7o8kbs7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:40:08.698866 [ 7645 ] {db5cebc9-a5d3-4d5c-809d-edb54921982e} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a241a 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>>>&) @ 0x0000000034938e37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003492abad 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927d21 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:40:09.384635 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:10.439397 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:11.537655 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:12.628879 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:12.815746 [ 7645 ] {a912d89a-5fce-48ea-bacf-f91d996b5ee5} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44172) (comment: 02374_analyzer_join_using.gen.sql) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (test_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f9d7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f0cc0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:12.817292 [ 7645 ] {a912d89a-5fce-48ea-bacf-f91d996b5ee5} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (test_value). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f9d7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f0cc0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:13.183057 [ 7645 ] {63b344b6-9702-432e-b02b-6309cbb25bae} executeQuery: Code: 47. DB::Exception: JOIN LEFT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44172) (comment: 02374_analyzer_join_using.gen.sql) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 USING (test_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f9d7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f0cc0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:13.184324 [ 7645 ] {63b344b6-9702-432e-b02b-6309cbb25bae} TCPHandler: Code: 47. DB::Exception: JOIN LEFT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 USING (test_value). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f9d7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f0cc0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:13.565449 [ 7645 ] {b5c58a9e-3394-40fe-a432-d91747de37df} executeQuery: Code: 47. DB::Exception: JOIN RIGHT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44172) (comment: 02374_analyzer_join_using.gen.sql) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 USING (test_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f9d7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f0cc0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:13.566581 [ 7645 ] {b5c58a9e-3394-40fe-a432-d91747de37df} TCPHandler: Code: 47. DB::Exception: JOIN RIGHT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 USING (test_value). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000334f9d7f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5089: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f0cc0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5193 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:13.668825 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:13.978611 [ 7645 ] {c0df3312-79b3-4811-bf0d-e5851237cb04} 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.10505.altinitytest (altinity build)) (from [::1]:44172) (comment: 02374_analyzer_join_using.gen.sql) (in query: SELECT 1 FROM test_table_join_1 AS t1 FULL JOIN test_table_join_2 AS t2 USING (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:40:13.981832 [ 7645 ] {c0df3312-79b3-4811-bf0d-e5851237cb04} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:40:14.772865 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:15.860549 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:16.929989 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:17.405506 [ 15427 ] {2a82636c-da32-452d-abc8-a54c95f8607b} 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.10505.altinitytest (altinity build)) (from [::1]:44224) (comment: 03058_analyzer_ambiguous_columns.sql) (in query: CREATE TABLE fact (`id` Int64, `animal_key` Int64, `color_key` Int64) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 28905, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.23534351587295532, replace_long_file_name_to_hash = true, max_file_name_length = 78, min_bytes_for_full_part_storage = 253388562, compact_parts_max_bytes_to_buffer = 413516250, compact_parts_max_granules_to_buffer = 55, compact_parts_merge_max_bytes_to_prefetch_part = 25812996, merge_max_block_size = 13454, 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 = 1, index_granularity_bytes = 23271675, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 88681, primary_key_compress_block_size = 81939), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:40:17.407271 [ 15427 ] {2a82636c-da32-452d-abc8-a54c95f8607b} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:40:17.979158 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:19.051852 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:19.139383 [ 15553 ] {3a3f37da-8eb8-4e05-ab31-a85c57172927} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40828) (comment: 01671_aggregate_function_group_bitmap_data.sql) (in query: INSERT INTO group_bitmap_data_test SELECT '2019-01-01', 1, number FROM numbers(1, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae794e4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abb2ace 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:40:19.143456 [ 15553 ] {3a3f37da-8eb8-4e05-ab31-a85c57172927} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae794e4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abb2ace 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:40:20.222177 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:21.334557 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:22.452350 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:23.716643 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:24.528552 [ 15427 ] {837b6307-707d-42aa-820b-fef8d1709a2d} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40880) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (in query: select * apply max from data_02052_1_wide0 settings max_read_buffer_size=0, max_threads=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:24.530192 [ 15427 ] {837b6307-707d-42aa-820b-fef8d1709a2d} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:24.799732 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:25.257480 [ 15427 ] {980429e9-a7c9-44f4-b4ad-2a02aba67a32} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40880) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (in query: select * apply max from data_02052_1_wide100000000 settings max_read_buffer_size=0, max_threads=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:25.258811 [ 15427 ] {980429e9-a7c9-44f4-b4ad-2a02aba67a32} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:25.562099 [ 15427 ] {ac7d12b4-be7c-4b77-b47e-c5e6de3594bb} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40880) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (in query: select * apply max from data_02052_10_wide0 settings max_read_buffer_size=0, max_threads=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:25.563408 [ 15427 ] {ac7d12b4-be7c-4b77-b47e-c5e6de3594bb} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:25.849993 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:25.865314 [ 15427 ] {3d387114-b7a6-466e-bc60-f49a14bc9860} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40880) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (in query: select * apply max from data_02052_10_wide100000000 settings max_read_buffer_size=0, max_threads=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:25.866486 [ 15427 ] {3d387114-b7a6-466e-bc60-f49a14bc9860} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:26.132511 [ 15427 ] {bdee0059-5a60-4667-9446-eda41cf9dc1a} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40880) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (in query: select * apply max from data_02052_100_wide0 settings max_read_buffer_size=0, max_threads=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:26.133812 [ 15427 ] {bdee0059-5a60-4667-9446-eda41cf9dc1a} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:26.543076 [ 15427 ] {13f5544e-4688-4286-b67a-dce573fe0e83} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40880) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (in query: select * apply max from data_02052_100_wide100000000 settings max_read_buffer_size=0, max_threads=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:26.544295 [ 15427 ] {13f5544e-4688-4286-b67a-dce573fe0e83} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000337d680a 4. ./build_docker/./src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x00000000337ae8d6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003becd9dd 6. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a6117b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a247f3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a23d33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2d2616 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:40:26.947432 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:28.039837 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:29.033141 [ 15427 ] {7a23d21b-3e8a-4e5e-a465-ac14610f0ad0} 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.10505.altinitytest (altinity build)) (from [::1]:40880) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (in query: -- avoid any optimizations with ignore(*) select * apply max from data_02052_10000_wide0 settings max_read_buffer_size=1, max_threads=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ced9b2 10. ./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&) @ 0x0000000039cefe6a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000032637b02 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263850d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce7344 14. ./contrib/llvm-project/libcxx/include/vector:547: 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) @ 0x0000000039ce6c69 15. ./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&) @ 0x00000000399a1328 16. ./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 @ 0x00000000399963b4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d2b850 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfb07da 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c05ddb3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfbccf3 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21ce0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 31. ? @ 0x00007f550c19fac3 2025.09.09 14:40:29.035993 [ 15427 ] {7a23d21b-3e8a-4e5e-a465-ac14610f0ad0} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ced9b2 10. ./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&) @ 0x0000000039cefe6a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000032637b02 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263850d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce7344 14. ./contrib/llvm-project/libcxx/include/vector:547: 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) @ 0x0000000039ce6c69 15. ./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&) @ 0x00000000399a1328 16. ./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 @ 0x00000000399963b4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d2b850 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfb07da 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c05ddb3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfbccf3 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21ce0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 31. ? @ 0x00007f550c19fac3 2025.09.09 14:40:29.077565 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:30.189585 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:31.451871 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:32.553976 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:33.687136 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:34.773062 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:35.675639 [ 3620 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {71093a84-ebed-448d-becc-536d0264ae9e::202509_224_229_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009cb0d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x00000000200978df 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7e39f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011a21f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3aa5f2 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a73f4 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:40:35.825354 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:36.892285 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:37.900166 [ 15553 ] {73b553a7-dd46-457a-b67d-5099b7b193e2} executeQuery: Code: 6. DB::Exception: Cannot parse ignore_data_skipping_indices (''). (CANNOT_PARSE_TEXT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39960) (comment: 02771_ignore_data_skipping_indices.sql) (in query: SELECT * FROM data_02771 SETTINGS ignore_data_skipping_indices='';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1520: 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&) @ 0x000000003bf0e57b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1617: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000003bf07667 6. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003c15c844 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c15c30f 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1036f2 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be928ba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8f80c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 2025.09.09 14:40:37.901600 [ 15553 ] {73b553a7-dd46-457a-b67d-5099b7b193e2} TCPHandler: Code: 6. DB::Exception: Cannot parse ignore_data_skipping_indices (''). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1520: 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&) @ 0x000000003bf0e57b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1617: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000003bf07667 6. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003c15c844 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c15c30f 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c1036f2 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003be928ba 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be8f80c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 2025.09.09 14:40:37.955774 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:39.042316 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:39.654658 [ 15553 ] {e070ebda-a674-4157-96b9-7ab56bdfe7c9} executeQuery: Code: 277. DB::Exception: Index `xy_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39960) (comment: 02771_ignore_data_skipping_indices.sql) (in query: SELECT * FROM data_02771 WHERE x = 1 AND y = 1 SETTINGS ignore_data_skipping_indices='xy_idx',force_data_skipping_indices='xy_idx' ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a48ac2 5. ./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) @ 0x000000003bf04769 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf16ef9 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1c8e0 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:40:39.657029 [ 15553 ] {e070ebda-a674-4157-96b9-7ab56bdfe7c9} TCPHandler: Code: 277. DB::Exception: Index `xy_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:609: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a48ac2 5. ./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) @ 0x000000003bf04769 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf000fa 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003beff885 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf16ef9 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf1c8e0 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce910d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce8b21 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:40:40.196184 [ 16153 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:41.067581 [ 15553 ] {568f58c7-950f-4a00-8c39-f0d15db9d26c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39960) (comment: 02771_ignore_data_skipping_indices.sql) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:41.068962 [ 15553 ] {568f58c7-950f-4a00-8c39-f0d15db9d26c} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:41.322635 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:42.428135 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:43.285194 [ 16153 ] {} HTTPServerRequest: Got an HTTP request with no content length and no chunked/multipart encoding, it may be impossible to distinguish graceful EOF from abnormal connection loss 2025.09.09 14:40:43.564288 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:43.979465 [ 16153 ] {} DynamicQueryHandler: Code: 381. DB::Exception: The Transfer-Encoding is not chunked and there is no Content-Length header for POST request. (HTTP_LENGTH_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Server/HTTPHandler.cpp:700: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0f90f 5. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 6. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 8. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 9. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 10. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 11. ? @ 0x00007f550c19fac3 12. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:40:44.658893 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:45.439546 [ 3618 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {583e1d76-5ec0-4ba5-90b6-72b5df496994::202509_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:40:45.774792 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:46.695490 [ 7641 ] {29195ca9-57df-4b00-8e7b-357735ddc9d7} executeQuery: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56398) (comment: 02111_global_context_temporary_tables.sql) (in query: -- { echo } SELECT * FROM remote('127.1', system.one, 1 IN 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x000000003591a991 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x00000000359172e5 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1479: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b2be38 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b128de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0f875 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033aec5f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a6b4bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9f253 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9fef2 16. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000382612f5 17. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003825b3bd 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x000000002fde9c75 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fde15b7 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 21. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce7524 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 2025.09.09 14:40:46.697550 [ 7641 ] {29195ca9-57df-4b00-8e7b-357735ddc9d7} TCPHandler: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x000000003591a991 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x00000000359172e5 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1479: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b2be38 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b128de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0f875 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033aec5f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a6b4bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9f253 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9fef2 16. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000382612f5 17. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003825b3bd 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x000000002fde9c75 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fde15b7 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 21. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce7524 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 2025.09.09 14:40:46.717057 [ 7641 ] {e23257cf-92ce-47a2-a557-dff9946444d5} executeQuery: Code: 60. DB::Exception: Table default.dummy does not exist: While processing 1 IN (dummy). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56398) (comment: 02111_global_context_temporary_tables.sql) (in query: SELECT * FROM remote('127.1', system.one, 1 IN 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x000000003591a991 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x00000000359172e5 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1479: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b2be38 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b128de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0f875 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033aec5f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a6b4bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9f253 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9fef2 16. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000382612f5 17. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003825b3bd 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x000000002fde9c75 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fde15b7 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 21. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce7524 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 2025.09.09 14:40:46.718531 [ 7641 ] {e23257cf-92ce-47a2-a557-dff9946444d5} TCPHandler: Code: 60. DB::Exception: Table default.dummy does not exist: While processing 1 IN (dummy). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x000000003591a991 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x00000000359172e5 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1479: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b2be38 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b128de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0f875 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033aec5f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a6b4bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9f253 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9fef2 16. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000382612f5 17. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003825b3bd 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x000000002fde9c75 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fde15b7 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 21. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce7524 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 2025.09.09 14:40:46.823214 [ 7641 ] {73b1d42c-1d25-4395-9ad1-b69d9a00d03f} executeQuery: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56398) (comment: 02111_global_context_temporary_tables.sql) (in query: SELECT * FROM remote('127.1', view(SELECT * FROM system.one), 1 IN 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x000000003591a991 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x00000000359172e5 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1479: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b2be38 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b128de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0f875 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033aec5f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a6b4bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9f253 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9fef2 16. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000382612f5 17. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003825b3bd 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x000000002fde9c75 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fde15b7 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 21. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce7524 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 2025.09.09 14:40:46.824631 [ 7641 ] {73b1d42c-1d25-4395-9ad1-b69d9a00d03f} TCPHandler: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x000000003591a991 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x00000000359172e5 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1479: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b2be38 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b128de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0f875 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033aec5f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a6b4bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9f253 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9fef2 16. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000382612f5 17. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003825b3bd 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x000000002fde9c75 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fde15b7 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 21. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce7524 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 2025.09.09 14:40:46.846486 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:46.861055 [ 7641 ] {65c0f6e0-dd47-4c1c-9c5d-78af7139cd05} executeQuery: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56398) (comment: 02111_global_context_temporary_tables.sql) (in query: SELECT * FROM remote('127.1', view(SELECT number AS id FROM numbers(2)), 1 IN 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x000000003591a991 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x00000000359172e5 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1479: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b2be38 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b128de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0f875 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033aec5f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a6b4bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9f253 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9fef2 16. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000382612f5 17. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003825b3bd 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x000000002fde9c75 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fde15b7 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 21. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce7524 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 2025.09.09 14:40:46.862331 [ 7641 ] {65c0f6e0-dd47-4c1c-9c5d-78af7139cd05} TCPHandler: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b0bbe1 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000033996eb3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339abd41 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x000000003591a991 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:0: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x00000000359172e5 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1479: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b2be38 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b128de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b0f875 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033aec5f5 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a6b4bf 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033a9f253 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033a9fef2 16. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000382612f5 17. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003825b3bd 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x000000002fde9c75 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fde15b7 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f7093 21. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000033744432 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000033457531 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334e5161 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e1c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce7524 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 2025.09.09 14:40:47.976383 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:49.120436 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:50.317420 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:51.396312 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:52.479972 [ 7641 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:53.546565 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:54.623367 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:55.687269 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:56.822562 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:57.877446 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:58.739629 [ 7645 ] {26b4b6dd-b807-46cd-86ad-7cb5658a8ea1} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58550) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1394: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a8bb0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:40:58.741903 [ 7645 ] {26b4b6dd-b807-46cd-86ad-7cb5658a8ea1} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1394: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a8bb0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:40:58.921164 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:40:59.695360 [ 7645 ] {74985d34-ad3b-4260-83cf-d2389e122651} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58550) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1401: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a7f30 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:40:59.696709 [ 7645 ] {74985d34-ad3b-4260-83cf-d2389e122651} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1401: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a7f30 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:40:59.999997 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:00.715041 [ 7645 ] {926d2f14-ed09-40dc-8e5e-540a7e1cde28} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58550) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1387: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a8570 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:00.716350 [ 7645 ] {926d2f14-ed09-40dc-8e5e-540a7e1cde28} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1387: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a8570 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:00.785159 [ 7645 ] {b0b4c6a4-f533-4bde-bad0-e8034dacd156} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58550) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1401: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a7f30 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:00.786237 [ 7645 ] {b0b4c6a4-f533-4bde-bad0-e8034dacd156} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1401: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a7f30 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:00.799482 [ 7645 ] {8fbd96cd-aa6d-49b5-aa60-1d1d4f8734b5} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58550) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1387: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a8570 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:00.800642 [ 7645 ] {8fbd96cd-aa6d-49b5-aa60-1d1d4f8734b5} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1387: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a8570 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:00.887033 [ 7645 ] {1ded2b5f-4d51-4fd0-9108-9a8e5f9dcf4b} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58550) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1394: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a8bb0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:00.888058 [ 7645 ] {1ded2b5f-4d51-4fd0-9108-9a8e5f9dcf4b} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861c137 4. ./build_docker/./src/Storages/AlterCommands.cpp:1394: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a8bb0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:01.075226 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:02.143277 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:03.221485 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:04.267780 [ 16153 ] {9968ca88-4af5-443d-bca2-a5a6b22855c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50480) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:41:04.270792 [ 16153 ] {9968ca88-4af5-443d-bca2-a5a6b22855c0} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003ac90db0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003ac8fba4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003ac8e53d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac67f0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b8801 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:41:04.466152 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:05.091195 [ 16153 ] {ecec72d9-a903-442c-a796-dc0ca9998069} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 2 ('error'): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50482) (in query: error here ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840753e 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) @ 0x000000003d197e4a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d197f91 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589e412 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&)>) @ 0x00000000358b6f77 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 15. ? @ 0x00007f550c19fac3 16. ? @ 0x00007f550c231850 2025.09.09 14:41:05.093320 [ 16153 ] {ecec72d9-a903-442c-a796-dc0ca9998069} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 2 ('error'): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840753e 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) @ 0x000000003d197e4a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d197f91 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589e412 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&)>) @ 0x00000000358b6f77 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 15. ? @ 0x00007f550c19fac3 16. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:41:05.609419 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:06.681676 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:07.873185 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:09.013148 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:10.162740 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:10.204026 [ 15427 ] {850cf930e9bf48838fbe54d6d4a1f344} executeQuery: Code: 117. DB::Exception: Index for LowCardinality is out of range. Dictionary size is 1, but found index with value 72057594037927936. (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59174) (in query: insert into test_13.tab settings input_format_defaults_for_omitted_fields=0 format TSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 4. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:0: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x00000000374580e3 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::SerializationLowCardinality::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 @ 0x0000000032745b7d 6. ./build_docker/./src/Formats/NativeReader.cpp:0: DB::NativeReader::read() @ 0x000000003ad72c96 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::receiveData(bool) @ 0x000000003abfffbc 8. ./build_docker/./src/Server/TCPHandler.cpp:1777: DB::TCPHandler::receivePacket() @ 0x000000003abce23d 9. ./build_docker/./src/Server/TCPHandler.cpp:859: DB::TCPHandler::readDataNext() @ 0x000000003abda504 10. ./build_docker/./src/Server/TCPHandler.cpp:987: DB::TCPHandler::processInsertQuery() @ 0x000000003abd1d1d 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:10.206230 [ 15427 ] {850cf930e9bf48838fbe54d6d4a1f344} TCPHandler: Code: 117. DB::Exception: Index for LowCardinality is out of range. Dictionary size is 1, but found index with value 72057594037927936. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 4. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:0: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x00000000374580e3 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::SerializationLowCardinality::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 @ 0x0000000032745b7d 6. ./build_docker/./src/Formats/NativeReader.cpp:0: DB::NativeReader::read() @ 0x000000003ad72c96 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::receiveData(bool) @ 0x000000003abfffbc 8. ./build_docker/./src/Server/TCPHandler.cpp:1777: DB::TCPHandler::receivePacket() @ 0x000000003abce23d 9. ./build_docker/./src/Server/TCPHandler.cpp:859: DB::TCPHandler::readDataNext() @ 0x000000003abda504 10. ./build_docker/./src/Server/TCPHandler.cpp:987: DB::TCPHandler::processInsertQuery() @ 0x000000003abd1d1d 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:11.324791 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:11.790037 [ 7645 ] {722db11dfb6243a0b02e447d253044e4} executeQuery: Code: 117. DB::Exception: LowCardinality indexes serialization type for Native format cannot use global dictionary. (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59184) (in query: insert into test_13.tab settings input_format_defaults_for_omitted_fields=0 format TSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:152: DB::IndexesSerializationType::deserialize(DB::ReadBuffer&, DB::ISerialization::DeserializeBinaryBulkSettings const&) @ 0x000000003275299a 5. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:0: DB::SerializationLowCardinality::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 @ 0x0000000032743a47 6. ./build_docker/./src/Formats/NativeReader.cpp:0: DB::NativeReader::read() @ 0x000000003ad72c96 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::receiveData(bool) @ 0x000000003abfffbc 8. ./build_docker/./src/Server/TCPHandler.cpp:1777: DB::TCPHandler::receivePacket() @ 0x000000003abce23d 9. ./build_docker/./src/Server/TCPHandler.cpp:859: DB::TCPHandler::readDataNext() @ 0x000000003abda504 10. ./build_docker/./src/Server/TCPHandler.cpp:987: DB::TCPHandler::processInsertQuery() @ 0x000000003abd1d1d 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:11.791647 [ 7645 ] {722db11dfb6243a0b02e447d253044e4} TCPHandler: Code: 117. DB::Exception: LowCardinality indexes serialization type for Native format cannot use global dictionary. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:152: DB::IndexesSerializationType::deserialize(DB::ReadBuffer&, DB::ISerialization::DeserializeBinaryBulkSettings const&) @ 0x000000003275299a 5. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:0: DB::SerializationLowCardinality::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 @ 0x0000000032743a47 6. ./build_docker/./src/Formats/NativeReader.cpp:0: DB::NativeReader::read() @ 0x000000003ad72c96 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::receiveData(bool) @ 0x000000003abfffbc 8. ./build_docker/./src/Server/TCPHandler.cpp:1777: DB::TCPHandler::receivePacket() @ 0x000000003abce23d 9. ./build_docker/./src/Server/TCPHandler.cpp:859: DB::TCPHandler::readDataNext() @ 0x000000003abda504 10. ./build_docker/./src/Server/TCPHandler.cpp:987: DB::TCPHandler::processInsertQuery() @ 0x000000003abd1d1d 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:12.463840 [ 7645 ] {f1475602-680b-4d2d-ace9-a286ec7f8ad8} executeQuery: Code: 62. DB::Exception: Empty query. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59184) (in 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840753e 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) @ 0x000000003d197e4a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d197f91 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589e412 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:41:12.464686 [ 7645 ] {f1475602-680b-4d2d-ace9-a286ec7f8ad8} TCPHandler: Code: 62. DB::Exception: Empty 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840753e 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) @ 0x000000003d197e4a 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d197f91 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003589e412 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:41:12.464716 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:12.465290 [ 7645 ] {f1475602-680b-4d2d-ace9-a286ec7f8ad8} TCPHandler: Can't skip data packets after query failure. 2025.09.09 14:41:13.529748 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:13.605594 [ 15427 ] {6bc3b37631e84524acebfdfe54a1d288} executeQuery: Code: 117. DB::Exception: No additional keys found. (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59192) (in query: insert into test_13.tab settings input_format_defaults_for_omitted_fields=0 format TSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:603: DB::SerializationLowCardinality::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 @ 0x000000003274da20 5. ./build_docker/./src/Formats/NativeReader.cpp:0: DB::NativeReader::read() @ 0x000000003ad72c96 6. ./contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::receiveData(bool) @ 0x000000003abfffbc 7. ./build_docker/./src/Server/TCPHandler.cpp:1777: DB::TCPHandler::receivePacket() @ 0x000000003abce23d 8. ./build_docker/./src/Server/TCPHandler.cpp:859: DB::TCPHandler::readDataNext() @ 0x000000003abda504 9. ./build_docker/./src/Server/TCPHandler.cpp:987: DB::TCPHandler::processInsertQuery() @ 0x000000003abd1d1d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:41:13.607030 [ 15427 ] {6bc3b37631e84524acebfdfe54a1d288} TCPHandler: Code: 117. DB::Exception: No additional keys found. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:603: DB::SerializationLowCardinality::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 @ 0x000000003274da20 5. ./build_docker/./src/Formats/NativeReader.cpp:0: DB::NativeReader::read() @ 0x000000003ad72c96 6. ./contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::receiveData(bool) @ 0x000000003abfffbc 7. ./build_docker/./src/Server/TCPHandler.cpp:1777: DB::TCPHandler::receivePacket() @ 0x000000003abce23d 8. ./build_docker/./src/Server/TCPHandler.cpp:859: DB::TCPHandler::readDataNext() @ 0x000000003abda504 9. ./build_docker/./src/Server/TCPHandler.cpp:987: DB::TCPHandler::processInsertQuery() @ 0x000000003abd1d1d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:41:14.679283 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:14.955166 [ 15427 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Hello received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./src/Common/Exception.h:0: _ZN2DB12NetExceptionC2IRA45_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000003ac0f5d6 3. ./build_docker/./src/Server/TCPHandler.cpp:1680: DB::TCPHandler::receiveUnexpectedHello() @ 0x000000003abf22d7 4. ./build_docker/./src/Server/TCPHandler.cpp:1742: DB::TCPHandler::receivePacket() @ 0x000000003abce364 5. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:41:15.845940 [ 7645 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:16.954780 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:18.041060 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:19.174230 [ 15427 ] {2725b068-a3d2-48f9-a6bd-62baead89a7d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49798) (comment: 01771_bloom_filter_not_has.sql) (in query: INSERT INTO bloom_filter_null_array SELECT [number] FROM numbers(10000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae794e4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abb2ace 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:41:19.177695 [ 15427 ] {2725b068-a3d2-48f9-a6bd-62baead89a7d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae794e4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abb2ace 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:41:19.270251 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:20.360209 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:21.447231 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:22.577140 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:23.667264 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:24.855662 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:26.010757 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:26.506598 [ 15427 ] {c17dde09-3b9a-4978-b70b-75e87030105e} Context: Server has databases (for example `ordinary_test_13`) 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.09.09 14:41:27.066644 [ 4134 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:28.403488 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:28.916925 [ 15427 ] {69a6d0a4-feb3-487b-b4c0-186f2556e05a} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE data_read; to attach existing table or CREATE TABLE data_read
; to create new table or ATTACH TABLE data_read FROM '/path/to/data/'
; to create new table and attach data. 2025.09.09 14:41:28.918828 [ 15427 ] {69a6d0a4-feb3-487b-b4c0-186f2556e05a} executeQuery: Code: 57. DB::Exception: Table ordinary_test_13.data_read already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45188) (comment: 02980_s3_plain_DROP_TABLE_ReplicatedMergeTree.sh) (in query: attach table data_read (key Int) engine=ReplicatedMergeTree('/tables/{database}/data', 'read') order by key settings max_suspicious_broken_parts=0, disk=disk(type=s3_plain, endpoint='http://localhost:11111/test/s3_plain/backups/ordinary_test_13', access_key_id='test', secret_access_key='testtest');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:28.920186 [ 15427 ] {69a6d0a4-feb3-487b-b4c0-186f2556e05a} TCPHandler: Code: 57. DB::Exception: Table ordinary_test_13.data_read 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:41:29.607881 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:30.702270 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:31.832000 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:33.093786 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:34.371970 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:35.566769 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:36.684103 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:37.846145 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:39.008157 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:40.163056 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:40.443749 [ 15427 ] {bd13451c-9b88-49b0-90f7-2886cb328d00} 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.10505.altinitytest (altinity build)) (from [::1]:54220) (comment: 02530_dictionaries_update_field.sh) (in query: SELECT key, value FROM dict_flat ORDER BY key 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:41:40.447620 [ 15427 ] {bd13451c-9b88-49b0-90f7-2886cb328d00} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:41:41.344557 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:42.429280 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:43.585323 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:44.690545 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:45.803901 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:46.937661 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:48.080005 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:49.183525 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:50.266481 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:51.555477 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:52.660527 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:53.739270 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:55.099115 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:56.262494 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:57.494324 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:58.576352 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:41:59.648467 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:00.753433 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:01.491158 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {133ed7fb-17c4-40b2-8c2e-a4fd23772b70::202509_1_146_29}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:42:01.841053 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:01.888018 [ 15553 ] {ab76d96b-716d-4df4-b039-df3c7d2a91c5} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35830) (comment: 02530_dictionaries_update_field.sh) (in query: DROP DICTIONARY dict_flat_custom), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:42:02.031621 [ 15553 ] {ab76d96b-716d-4df4-b039-df3c7d2a91c5} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:42:03.071111 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:04.208467 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:05.396514 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:06.505305 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:07.827131 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:08.931972 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:09.996273 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:11.057329 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:12.123569 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:13.190594 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:14.267868 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:15.339601 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:16.474003 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:16.868675 [ 3624 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {735d8f76-3afe-45b6-b2c9-e3d138f09c35::202509_1_84_25}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:42:16.875424 [ 15427 ] {ede0c7da-94ea-4485-8073-0a6d41afb7d5} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44706) (comment: 02530_dictionaries_update_field.sh) (in query: DROP DICTIONARY dict_hashed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:42:16.877436 [ 15427 ] {ede0c7da-94ea-4485-8073-0a6d41afb7d5} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:42:17.616724 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:18.657456 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:19.705978 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:20.770976 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:21.831288 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:22.938978 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:23.072178 [ 15427 ] {0f800586-4e0d-4ea0-b68a-49dd28b0777f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44836) (comment: 02530_dictionaries_update_field.sh) (in query: SELECT key, value FROM dict_hashed_custom ORDER BY key 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:42:23.075668 [ 15427 ] {0f800586-4e0d-4ea0-b68a-49dd28b0777f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=733). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:42:24.013320 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:25.083017 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:26.245166 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:27.436619 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:28.469488 [ 4301 ] {} ExternalDictionariesLoader: Could not update external dictionary '8e97a114-35ed-4c4a-9afc-b1d1bbc6f92d', leaving the previous version, next update is scheduled at 2025-09-09 14:42:31: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): while reading column last_insert_time at /var/lib/clickhouse/store/4d8/4d87edc7-5e06-4be4-becc-603b1acc007a/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000307563fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c40 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521b1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073082e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073194f 11. DB::ReadBuffer::next() @ 0x00000000095b3aaf 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x00000000206e4b9a 13. DB::ReadBuffer::next() @ 0x00000000095b3aaf 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320dca93 15. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000320dc342 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000320dc92d 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000003278ad67 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: 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 @ 0x0000000032639a70 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000038d4bb50 20. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::LogSource::generate() @ 0x0000000038d498bd 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aec05d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aec0ea4 28. void DB::mergeBlockWithPipe<(DB::DictionaryKeyType)0>(unsigned long, DB::Block&, DB::QueryPipeline) @ 0x0000000020df48b7 29. DB::FlatDictionary::updateData() @ 0x0000000020d96cfd 30. DB::FlatDictionary::loadData() @ 0x0000000020d85e7e 31. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000020d85864 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:42:28.485311 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:29.550131 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:30.685054 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:31.762470 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:32.859647 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:33.179520 [ 3808 ] {} ExternalDictionariesLoader: Could not update external dictionary '27538dee-e188-4b11-90fa-b5e2b5692987', leaving the previous version, next update is scheduled at 2025-09-09 14:42:36: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): while reading column key at /var/lib/clickhouse/store/4d8/4d87edc7-5e06-4be4-becc-603b1acc007a/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000307563fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c40 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521b1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073082e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073194f 11. DB::ReadBuffer::next() @ 0x00000000095b3aaf 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x00000000206e4b9a 13. DB::ReadBuffer::next() @ 0x00000000095b3aaf 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320dca93 15. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000320dc342 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000320dc92d 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000003278d3c7 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: 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 @ 0x0000000032639a70 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000038d4bb50 20. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::LogSource::generate() @ 0x0000000038d498bd 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae4a653 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aec05d2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aec0ea4 28. void DB::mergeBlockWithPipe<(DB::DictionaryKeyType)0>(unsigned long, DB::Block&, DB::QueryPipeline) @ 0x0000000020df48b7 29. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::updateData() @ 0x0000000021e78a7b 30. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::loadData() @ 0x0000000021e6a570 31. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x0000000021e69368 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:42:34.048235 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:35.200323 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:36.425500 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:37.556172 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:37.571212 [ 3612 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {133ed7fb-17c4-40b2-8c2e-a4fd23772b70::202509_1_151_30}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:42:38.739903 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:39.890306 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:41.036048 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:42.112161 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:43.262953 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:44.448597 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:45.565287 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:46.811029 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:47.953709 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:49.079274 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:50.194594 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:51.307471 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:52.373127 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:53.450929 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:54.615376 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:55.661571 [ 15553 ] {fd74023b-3284-4208-b89d-3b62f2aa4bee} 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.10505.altinitytest (altinity build)) (from [::1]:58262) (comment: 02530_dictionaries_update_field.sh) (in query: SELECT key, value FROM dict_complex_key_hashed_custom ORDER BY key 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:42:55.664625 [ 15553 ] {fd74023b-3284-4208-b89d-3b62f2aa4bee} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:42:55.745483 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:55.839793 [ 3622 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {22b0a30e-8738-451d-9c67-584e1807201a::202509_1_96_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:42:56.793605 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:58.085161 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:42:59.147002 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:00.204268 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:01.383852 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:02.094151 [ 15427 ] {974600b4-d4e4-464a-9dec-8289d0c6ee5e} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47194) (comment: 02530_dictionaries_update_field.sh) (in query: DROP DICTIONARY dict_complex_key_hashed_custom), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:43:02.096284 [ 15427 ] {974600b4-d4e4-464a-9dec-8289d0c6ee5e} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349320cb 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:43:02.467474 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:02.896607 [ 15427 ] {2c310649-e194-47e7-aa15-03b88d6206a8} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_13.table_for_update_field_dictionary (4d87edc7-5e06-4be4-becc-603b1acc007a), because some tables depend on it: test_13.dict_complex_key_hashed_custom, test_13.dict_hashed, test_13.dict_flat_custom. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47202) (comment: 02530_dictionaries_update_field.sh) (in query: DROP TABLE IF EXISTS table_for_update_field_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x00000000339e47cd 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c9c1f 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339cb339 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034930182 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:43:02.898896 [ 15427 ] {2c310649-e194-47e7-aa15-03b88d6206a8} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_13.table_for_update_field_dictionary (4d87edc7-5e06-4be4-becc-603b1acc007a), because some tables depend on it: test_13.dict_complex_key_hashed_custom, test_13.dict_hashed, test_13.dict_flat_custom. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x00000000339e47cd 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c9c1f 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339cb339 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034930182 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 19. ? @ 0x00007f550c19fac3 20. ? @ 0x00007f550c231850 2025.09.09 14:43:03.577169 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:04.641266 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:05.689027 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:06.768421 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:07.900445 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:08.989178 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:10.119207 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:11.210466 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:12.294951 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:13.465254 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:14.647176 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:15.861008 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:16.950987 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:18.051032 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:19.193984 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:19.690689 [ 15553 ] {5b77f793-ed70-4d27-b1ba-880496978ba6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37422) (comment: 02752_space_function.sql) (in query: SELECT space(3::UInt64), length(space(3::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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:43:19.692161 [ 15553 ] {5b77f793-ed70-4d27-b1ba-880496978ba6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=733). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:43:20.278474 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:21.375031 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:22.438891 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:23.691478 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:24.764283 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:25.832401 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:26.180032 [ 3617 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9a965849-da2f-426a-8ede-2051c1b8090e::202509_1_150_30}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009cb0d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x00000000200978df 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7e39f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011a21f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3aa5f2 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a73f4 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:43:26.876150 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:27.950079 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:29.045008 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:30.183771 [ 15553 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:43:59.691809 [ 15427 ] {dfca5477-33fa-4e97-a7c2-0c0fe1405c1c} executeQuery: Code: 6. DB::Exception: Cannot parse string '2021-1-01 00:00:00' as DateTime: syntax error at position 10 (parsed just '2021-1-01 '): In scope SELECT toDateTime(format('{}-{}-01 00:00:00', '2021', '1')). (CANNOT_PARSE_TEXT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36312) (comment: 01750_parsing_exception.sh) (in query: SELECT toDateTime(format('{}-{}-01 00:00:00', '2021', '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ea802 4. bool DB::callOnIndexAndDataType::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::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008e9b727 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e2f9a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:43:59.695344 [ 15427 ] {dfca5477-33fa-4e97-a7c2-0c0fe1405c1c} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2021-1-01 00:00:00' as DateTime: syntax error at position 10 (parsed just '2021-1-01 '): In scope SELECT toDateTime(format('{}-{}-01 00:00:00', '2021', '1')). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ea802 4. bool DB::callOnIndexAndDataType::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::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008e9b727 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e2f9a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 2025.09.09 14:44:03.473048 [ 15553 ] {950b2585-0533-4dbf-8d60-c7c37a76a3cc} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage GenerateRandom. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50158) (comment: 02516_projections_with_rollup.sql) (in query: DROP TABLE rng;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:44:03.476654 [ 15553 ] {950b2585-0533-4dbf-8d60-c7c37a76a3cc} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage GenerateRandom. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc6e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492fbf5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492a59f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034927a9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000349272b3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 2025.09.09 14:44:10.599383 [ 15427 ] {e745618d-6a0f-41c1-9311-e753fc55cb56} 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.10505.altinitytest (altinity build)) (from [::1]:36344) (comment: 01158_zookeeper_log_long.sql) (in query: select type, has_watch, op_num, path, is_ephemeral, is_sequential, version, requests_size, request_idx, error, watch_type, watch_state, path_created, stat_version, stat_cversion, stat_dataLength, stat_numChildren from system.zookeeper_log where (session_id, xid) in ( select session_id, xid from system.zookeeper_log where path like '/test/01158/' || currentDatabase() || '/rmt/blocks/%' and op_num not in (1, 12, 500) and (query_id='' or query_id in (select query_id from system.query_log where current_database=currentDatabase() and event_date>=yesterday())) ) order by xid, type, request_idx;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d2b850 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfb07da 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c05ddb3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfbccf3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21ce0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 26. ? @ 0x00007f550c19fac3 27. ? @ 0x00007f550c231850 2025.09.09 14:44:10.611815 [ 15427 ] {e745618d-6a0f-41c1-9311-e753fc55cb56} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d2b850 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfb07da 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c05ddb3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfbccf3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21ce0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 26. ? @ 0x00007f550c19fac3 27. ? @ 0x00007f550c231850 2025.09.09 14:44:13.592003 [ 15427 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b4aa 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374b80e 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000003374c950 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abf97e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abcde18 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb0925 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:44:24.467744 [ 21346 ] {25ead2ee-b7b8-4d49-83eb-80e05f6de398} executeQuery: Code: 16. DB::Exception: No such column ord in table test_13.t (a7930f2b-2b73-40f9-bf4a-1997f50eb56c). (NO_SUCH_COLUMN_IN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59514) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa08d8d 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:222: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000034b94830 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) @ 0x0000000034b921d7 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034baa9f5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:44:24.474489 [ 21346 ] {25ead2ee-b7b8-4d49-83eb-80e05f6de398} TCPHandler: Code: 16. DB::Exception: No such column ord in table test_13.t (a7930f2b-2b73-40f9-bf4a-1997f50eb56c). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa08d8d 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:222: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000034b94830 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) @ 0x0000000034b921d7 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034baa9f5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:44:42.159897 [ 3624 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {82a03bbc-c240-4760-ac41-7d5c29a949ce::202509_1_149_30}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:44:43.036515 [ 3621 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {82a03bbc-c240-4760-ac41-7d5c29a949ce::202509_1_149_30}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007f550c19fac3 29. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:44:51.227779 [ 21345 ] {4a483813-8873-4bb4-99a1-46bbc13d9aa4} executeQuery: Code: 57. DB::Exception: Table test_3.t_sparse_pk already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43690) (comment: 01780_column_sparse_pk.sql) (in query: CREATE TABLE t_sparse_pk (`k` UInt64, `v` UInt64 CODEC(NONE)) ENGINE = MergeTree ORDER BY k SETTINGS ratio_of_defaults_for_sparse_serialization = 0., index_granularity = 30, min_bytes_for_wide_part = 658802905, replace_long_file_name_to_hash = true, max_file_name_length = 73, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 515407858, compact_parts_max_granules_to_buffer = 244, compact_parts_merge_max_bytes_to_prefetch_part = 8178520, merge_max_block_size = 3722, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1824190478, vertical_merge_algorithm_min_rows_to_activate = 777007, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7855411136, index_granularity_bytes = 23796238, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 27000, primary_key_compress_block_size = 27177), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:44:51.231490 [ 21345 ] {4a483813-8873-4bb4-99a1-46bbc13d9aa4} TCPHandler: Code: 57. DB::Exception: Table test_3.t_sparse_pk 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:44:53.626592 [ 21345 ] {8c9da19f-ff41-42bd-9b61-f43d074d709f} 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.10505.altinitytest (altinity build)) (from [::1]:43706) (comment: 01291_aggregation_in_order.sql) (in query: SELECT a FROM pk_order GROUP BY 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ced9b2 10. ./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&) @ 0x0000000039cefe6a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000032637b02 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263850d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce7344 14. ./contrib/llvm-project/libcxx/include/vector:547: 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) @ 0x0000000039ce6c69 15. ./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&) @ 0x00000000399a1328 16. ./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 @ 0x00000000399963b4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d2b850 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfb07da 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c05ddb3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfbccf3 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21ce0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 31. ? @ 0x00007f550c19fac3 2025.09.09 14:44:53.634184 [ 21345 ] {8c9da19f-ff41-42bd-9b61-f43d074d709f} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ced9b2 10. ./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&) @ 0x0000000039cefe6a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000032637b02 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263850d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce7344 14. ./contrib/llvm-project/libcxx/include/vector:547: 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) @ 0x0000000039ce6c69 15. ./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&) @ 0x00000000399a1328 16. ./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 @ 0x00000000399963b4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d2b850 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfb07da 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c05ddb3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfbccf3 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21ce0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 31. ? @ 0x00007f550c19fac3 2025.09.09 14:45:04.987904 [ 21345 ] {edca24f5-c81e-4d4c-96fc-b8898df9f0c3} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57530) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:04.996686 [ 21345 ] {edca24f5-c81e-4d4c-96fc-b8898df9f0c3} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:05.488910 [ 21347 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:57546, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204c0eb0 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c1e41 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ea7cd 6. DB::ReadBuffer::next() @ 0x00000000095b3aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abb079e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:06.100157 [ 21345 ] {e9922381-8b9e-4bbd-ba9b-6693b35a27dc} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57550) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:06.174566 [ 21345 ] {e9922381-8b9e-4bbd-ba9b-6693b35a27dc} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:07.562524 [ 21347 ] {af2baee9-7fe9-462a-94bb-26aabcd2d93c} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:57566). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57566) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`mergetree_00754` AS `__table1` PREWHERE (`__table1`.`a` = 0) AND (`__table1`.`b` = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5781 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:07.641329 [ 21347 ] {af2baee9-7fe9-462a-94bb-26aabcd2d93c} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:57566). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0729a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd8e6a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2fa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:07.642143 [ 21347 ] {af2baee9-7fe9-462a-94bb-26aabcd2d93c} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:57566). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5781 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:07.643421 [ 21347 ] {af2baee9-7fe9-462a-94bb-26aabcd2d93c} TCPHandler: Client has gone away. 2025.09.09 14:45:08.782044 [ 21345 ] {d7da164d-4ff8-440a-845a-00b8f34aa241} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38834) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 2 AND b = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:08.785989 [ 21345 ] {d7da164d-4ff8-440a-845a-00b8f34aa241} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:09.231914 [ 21346 ] {3057aeb1-1c24-4d68-8d4f-17d70daa165a} 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.10505.altinitytest (altinity build)) (from [::1]:43658) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/HDFSCommon.cpp:172: DB::createHDFSFS(hdfsBuilder*) @ 0x0000000030b20f59 5. ./build_docker/./src/Disks/ObjectStorages/HDFS/HDFSObjectStorage.cpp:35: DB::HDFSObjectStorage::initializeHDFSFS() const @ 0x0000000030fbe62e 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&) @ 0x0000000030fc2f9e 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:31: DB::StorageObjectStorageSink::StorageObjectStorageSink(std::shared_ptr, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr, String const&) @ 0x0000000030a1494f 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&) @ 0x0000000030a0167f 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000309ee744 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&) @ 0x000000003ba7828f 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*) @ 0x0000000034b98bc1 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&) @ 0x0000000034b9bbcf 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba2360 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:45:09.234556 [ 21346 ] {3057aeb1-1c24-4d68-8d4f-17d70daa165a} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/HDFSCommon.cpp:172: DB::createHDFSFS(hdfsBuilder*) @ 0x0000000030b20f59 5. ./build_docker/./src/Disks/ObjectStorages/HDFS/HDFSObjectStorage.cpp:35: DB::HDFSObjectStorage::initializeHDFSFS() const @ 0x0000000030fbe62e 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&) @ 0x0000000030fc2f9e 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:31: DB::StorageObjectStorageSink::StorageObjectStorageSink(std::shared_ptr, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr, String const&) @ 0x0000000030a1494f 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&) @ 0x0000000030a0167f 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000309ee744 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&) @ 0x000000003ba7828f 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*) @ 0x0000000034b98bc1 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&) @ 0x0000000034b9bbcf 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba2360 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:45:10.374217 [ 3651 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1491cbcc-17c2-43a1-b3d4-64e7d5563d01::lambda}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000003972dea1 8. ./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>*) @ 0x0000000039726c72 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearOldPartsFromFilesystem(bool) @ 0x000000003972657c 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:1478: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003a364e7b 11. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b0e7d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968b3b3 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968d099 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969c3df 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:18.079400 [ 21345 ] {9d68a44a-5154-4cc9-9c24-57b7e7782d44} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38382) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b <= 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:18.090607 [ 21345 ] {9d68a44a-5154-4cc9-9c24-57b7e7782d44} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:19.457934 [ 21345 ] {b0864252-2993-4705-97de-ccf7f6b53059} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38386) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 WHERE c LIKE '%l%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:19.464098 [ 21345 ] {b0864252-2993-4705-97de-ccf7f6b53059} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:19.653317 [ 15427 ] {a3f579f3-1d2e-42ad-8ea3-34a3fb602c93} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38394). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38394) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`mergetree_00754` AS `__table1` PREWHERE `__table1`.`a` = 0 WHERE `__table1`.`c` LIKE '%l%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:19.653324 [ 15553 ] {f939a80a-3904-49a9-9831-0614af5bcd6a} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38818). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38818) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`mergetree_00754` AS `__table1` PREWHERE (`__table1`.`a` = 0) AND (`__table1`.`b` <= 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:19.658013 [ 15427 ] {a3f579f3-1d2e-42ad-8ea3-34a3fb602c93} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38394). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0729a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd8e6a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2fa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:19.658377 [ 15427 ] {a3f579f3-1d2e-42ad-8ea3-34a3fb602c93} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38394). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:19.658984 [ 15427 ] {a3f579f3-1d2e-42ad-8ea3-34a3fb602c93} TCPHandler: Client has gone away. 2025.09.09 14:45:19.702667 [ 15553 ] {f939a80a-3904-49a9-9831-0614af5bcd6a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38818). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0729a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd8e6a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2fa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:19.703203 [ 15553 ] {f939a80a-3904-49a9-9831-0614af5bcd6a} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38818). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:19.704054 [ 15553 ] {f939a80a-3904-49a9-9831-0614af5bcd6a} TCPHandler: Client has gone away. 2025.09.09 14:45:21.194141 [ 21345 ] {2b23add1-98a5-42b3-baa9-c12e56ee4b64} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38398) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 OR a = 1 AND b = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:21.204846 [ 21345 ] {2b23add1-98a5-42b3-baa9-c12e56ee4b64} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:21.255815 [ 15553 ] {923642b7-520f-4028-9b6e-9ffaf2cf1d71} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38410). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38410) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`mergetree_00754` AS `__table1` PREWHERE (`__table1`.`a` = 0) OR ((`__table1`.`a` = 1) AND (`__table1`.`b` = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:21.260989 [ 15553 ] {923642b7-520f-4028-9b6e-9ffaf2cf1d71} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38410). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0729a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd8e6a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2fa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:21.261520 [ 15553 ] {923642b7-520f-4028-9b6e-9ffaf2cf1d71} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38410). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:21.262327 [ 15553 ] {923642b7-520f-4028-9b6e-9ffaf2cf1d71} TCPHandler: Client has gone away. 2025.09.09 14:45:22.561095 [ 21345 ] {94aca556-e6b2-4b9a-92ec-abb79e4066cd} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38426) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0 OR a = 2 AND b = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:22.567514 [ 21345 ] {94aca556-e6b2-4b9a-92ec-abb79e4066cd} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:22.726829 [ 15553 ] {e019a369-c7a9-4e04-8e4a-8774a928d4e7} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38442). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38442) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`mergetree_00754` AS `__table1` PREWHERE ((`__table1`.`a` = 0) AND (`__table1`.`b` = 0)) OR ((`__table1`.`a` = 2) AND (`__table1`.`b` = 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:22.733874 [ 15553 ] {e019a369-c7a9-4e04-8e4a-8774a928d4e7} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38442). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0729a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd8e6a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2fa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:22.734239 [ 15553 ] {e019a369-c7a9-4e04-8e4a-8774a928d4e7} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38442). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:22.735491 [ 15553 ] {e019a369-c7a9-4e04-8e4a-8774a928d4e7} TCPHandler: Client has gone away. 2025.09.09 14:45:23.732974 [ 21345 ] {24c7a113-b117-476c-bd15-f355bdba516f} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38454) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0 OR c LIKE '%l%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:23.738807 [ 21345 ] {24c7a113-b117-476c-bd15-f355bdba516f} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d41bca 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003a872057 4. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a84f08c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003230f0bb 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000322ef0c7 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:367: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x00000000322d0976 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323500b0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234df31 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003234d286 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000003234a772 2025.09.09 14:45:23.974265 [ 15553 ] {abaa08a1-1c6d-416f-9749-a75de3cc0fd2} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38460). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38460) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`mergetree_00754` AS `__table1` PREWHERE ((`__table1`.`a` = 0) AND (`__table1`.`b` = 0)) OR (`__table1`.`c` LIKE '%l%')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:23.980362 [ 15553 ] {abaa08a1-1c6d-416f-9749-a75de3cc0fd2} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38460). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac0729a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abd8e6a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2fa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:23.981004 [ 15553 ] {abaa08a1-1c6d-416f-9749-a75de3cc0fd2} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38460). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c7ab8 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7f3317 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abdd9bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd5015 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:23.981795 [ 15553 ] {abaa08a1-1c6d-416f-9749-a75de3cc0fd2} TCPHandler: Client has gone away. 2025.09.09 14:45:28.400162 [ 21345 ] {4688a6f6-8f87-4a9d-a2bd-5ac2c803f735} executeQuery: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString('string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55588) (comment: 01277_random_fixed_string.sql) (in query: SELECT randomFixedString('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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bc023ee 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:45:28.402394 [ 21345 ] {4688a6f6-8f87-4a9d-a2bd-5ac2c803f735} TCPHandler: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString('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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bc023ee 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:45:30.411401 [ 21345 ] {ce6c4031-e73b-4ff2-8e6b-bcace3995289} executeQuery: Code: 69. DB::Exception: FixedString size must be positive: In scope SELECT randomFixedString(0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55588) (comment: 01277_random_fixed_string.sql) (in query: SELECT randomFixedString(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. DB::DataTypeFixedString::DataTypeFixedString(unsigned long) @ 0x000000000861fc8a 5. std::shared_ptr std::allocate_shared[abi:v15007], unsigned long const&, void>(std::allocator const&, unsigned long const&) @ 0x0000000008666298 6. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bc02010 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:45:30.413553 [ 21345 ] {ce6c4031-e73b-4ff2-8e6b-bcace3995289} TCPHandler: Code: 69. DB::Exception: FixedString size must be positive: In scope SELECT randomFixedString(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. DB::DataTypeFixedString::DataTypeFixedString(unsigned long) @ 0x000000000861fc8a 5. std::shared_ptr std::allocate_shared[abi:v15007], unsigned long const&, void>(std::allocator const&, unsigned long const&) @ 0x0000000008666298 6. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bc02010 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 2025.09.09 14:45:31.624114 [ 21345 ] {9695d74d-eedb-4fe4-aa09-15759b98df5a} executeQuery: Code: 44. DB::Exception: First argument for function randomFixedString must be constant: In scope SELECT randomFixedString(rand() % 10). (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55588) (comment: 01277_random_fixed_string.sql) (in query: SELECT randomFixedString(rand() % 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bc0221d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:45:31.626571 [ 21345 ] {9695d74d-eedb-4fe4-aa09-15759b98df5a} TCPHandler: Code: 44. DB::Exception: First argument for function randomFixedString must be constant: In scope SELECT randomFixedString(rand() % 10). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bc0221d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cf9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b609e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6090da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60adcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a6d8d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 31. ? @ 0x00007f550c19fac3 2025.09.09 14:45:36.462503 [ 21347 ] {35b660cd-5e4d-41cd-afeb-e4c95af4f68f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38846) (comment: 01518_nullable_aggregate_states2.sql) (in query: select count() from testNullableStates;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:45:36.467744 [ 21347 ] {35b660cd-5e4d-41cd-afeb-e4c95af4f68f} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:45:44.078855 [ 21825 ] {ad2ee17d-f4eb-408c-a300-3840cc0c96b4} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42800) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:44.101220 [ 21825 ] {ad2ee17d-f4eb-408c-a300-3840cc0c96b4} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:44.247273 [ 21827 ] {3332501a-0aca-40ff-a55c-b1e679c9b974} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42806) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:44.247274 [ 21831 ] {7eec88e2-155f-480d-85bd-6c41ab3a847a} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42840) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:44.250869 [ 15427 ] {cf9212c3-7957-4ebf-a6cf-f4a001541f73} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42832) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:44.252338 [ 21831 ] {7eec88e2-155f-480d-85bd-6c41ab3a847a} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:44.252353 [ 21827 ] {3332501a-0aca-40ff-a55c-b1e679c9b974} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:44.273770 [ 15427 ] {cf9212c3-7957-4ebf-a6cf-f4a001541f73} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:46.248453 [ 3622 ] {} 78dab2ae-fda4-4ec1-80d6-c167149e1dec::-7_0_0_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:46.249712 [ 3622 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {78dab2ae-fda4-4ec1-80d6-c167149e1dec::-7_0_0_0_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:46.276257 [ 21909 ] {4396b47a-3305-470b-9206-b09ed038e0f0} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43076) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000389234fa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b489 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:46.276307 [ 21919 ] {0651243b-294b-4778-bf07-9eaa5d866374} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43100) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000389234fa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b489 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:46.276539 [ 21830 ] {4d20af57-eced-4960-a416-71fd889d1dab} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43090) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000389234fa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b489 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:46.279149 [ 21919 ] {0651243b-294b-4778-bf07-9eaa5d866374} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000389234fa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b489 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:46.280601 [ 21830 ] {4d20af57-eced-4960-a416-71fd889d1dab} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000389234fa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b489 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:46.281826 [ 21909 ] {4396b47a-3305-470b-9206-b09ed038e0f0} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d1a64 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000389234fa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b489 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:46.881116 [ 3611 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-6_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/5f4/5f468197-710e-44c8-b6bc-374ef3155aca/-6_0_0_0/ in table test_13.alter_table1 (5f468197-710e-44c8-b6bc-374ef3155aca) located on disk default of type local, from mark 0 with max_rows_to_read = 5056): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000307563fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c40 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521b1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073082e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073194f 11. DB::ReadBuffer::next() @ 0x00000000095b3aaf 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320df958 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320e3cae 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320e486d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032786242 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: 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 @ 0x0000000032639a70 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: 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>>>*) @ 0x0000000039c7447d 18. ./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>>&) @ 0x0000000039cccfd1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c99152 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cbc936 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb5073 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2fe06 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbf454 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21f50 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:46.881770 [ 3611 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-6_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/5f4/5f468197-710e-44c8-b6bc-374ef3155aca/-6_0_0_0/ in table test_13.alter_table1 (5f468197-710e-44c8-b6bc-374ef3155aca) located on disk default of type local, from mark 0 with max_rows_to_read = 5056): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000307563fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c40 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521b1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073082e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073194f 11. DB::ReadBuffer::next() @ 0x00000000095b3aaf 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320df958 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320e3cae 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320e486d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032786242 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: 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 @ 0x0000000032639a70 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: 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>>>*) @ 0x0000000039c7447d 18. ./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>>&) @ 0x0000000039cccfd1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c99152 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cbc936 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb5073 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2fe06 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbf454 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21f50 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:47.072387 [ 3622 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-6_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:47.073153 [ 3622 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-6_0_0_0_1}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:47.221768 [ 3619 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-6_3_3_0_6 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:47.252981 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-6_3_3_0_6}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:47.478429 [ 3614 ] {5f468197-710e-44c8-b6bc-374ef3155aca::-6_0_0_0_1} 5f468197-710e-44c8-b6bc-374ef3155aca::-6_0_0_0_1 (MutateFromLogEntryTask): Code: 40. DB::Exception: Part -6_0_0_0_1 from r1 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.09.09 14:45:47.483591 [ 3616 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-3_0_0_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d0a522 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f98d71 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034fa370b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e6f5d2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e69796 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e54926 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0075fe 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a003d6c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:47.486335 [ 3616 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-3_0_0_0_3}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d0a522 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be21ac3 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be900e5 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f98d71 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034fa370b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e6f5d2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e69796 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e54926 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0075fe 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a003d6c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:47.546544 [ 21834 ] {35c21a41-8005-4c34-9fc9-be28987cf0de} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39284) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:47.554470 [ 21834 ] {35c21a41-8005-4c34-9fc9-be28987cf0de} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:47.587005 [ 21831 ] {1a95ec0b-eb32-48eb-859e-ab4be5fe77da} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39292) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:47.594143 [ 21831 ] {1a95ec0b-eb32-48eb-859e-ab4be5fe77da} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:47.681041 [ 21951 ] {6c8fc008-4bf0-4150-87c0-d6132bc6cde1} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39310) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:47.687482 [ 21951 ] {6c8fc008-4bf0-4150-87c0-d6132bc6cde1} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:47.974409 [ 21830 ] {c7ded20d-98ef-421b-8a37-55007457593d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39256) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: SELECT * FROM system.parts 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000347b2210 7. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000347aaf3c 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347e621b 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347e4063 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347eb266 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347eb01f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:47.984161 [ 21830 ] {c7ded20d-98ef-421b-8a37-55007457593d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000347b2210 7. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000347aaf3c 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347e621b 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347e4063 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347eb266 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347eb01f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 2025.09.09 14:45:48.540605 [ 3623 ] {5f468197-710e-44c8-b6bc-374ef3155aca::-3_0_0_0_3} 5f468197-710e-44c8-b6bc-374ef3155aca::-3_0_0_0_3 (MutateFromLogEntryTask): Code: 40. DB::Exception: Part -3_0_0_0_3 from r1 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.09.09 14:45:48.734352 [ 21831 ] {7fdc5839-d67b-4e5c-b17a-e80f9c8b604a} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39354) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:48.739382 [ 21831 ] {7fdc5839-d67b-4e5c-b17a-e80f9c8b604a} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:48.814856 [ 21919 ] {4b3ea341-4832-439c-9260-90cdfb32872e} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39380) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:48.818245 [ 21919 ] {4b3ea341-4832-439c-9260-90cdfb32872e} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:48.981459 [ 21972 ] {4acdb7ba-0723-44f8-a86a-2abbbe74dc9c} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39400) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:48.984113 [ 21972 ] {4acdb7ba-0723-44f8-a86a-2abbbe74dc9c} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:49.847648 [ 21830 ] {8912d7a3-0340-4242-96d4-53ce15919db7} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39420) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:49.853674 [ 21830 ] {8912d7a3-0340-4242-96d4-53ce15919db7} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.030771 [ 21815 ] {f69e358c-0384-4d56-a29f-45c2c3ef07cd} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39454) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.058686 [ 21815 ] {f69e358c-0384-4d56-a29f-45c2c3ef07cd} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.173583 [ 15553 ] {a5c5c185-9ca7-4682-bb9e-c743be4c1fc3} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39426) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.180825 [ 21818 ] {dc9d448d-4509-4e15-a095-57dd02bdc64a} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39466) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.199714 [ 15553 ] {a5c5c185-9ca7-4682-bb9e-c743be4c1fc3} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.205258 [ 21818 ] {dc9d448d-4509-4e15-a095-57dd02bdc64a} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.209734 [ 21834 ] {a406f44b-8b3c-4c87-ab21-fd80fbaeca70} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39482) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.213012 [ 21834 ] {a406f44b-8b3c-4c87-ab21-fd80fbaeca70} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.626712 [ 3624 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_14 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:50.627577 [ 3624 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_14}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:50.685587 [ 21834 ] {9fbc6118-2d76-43c6-8697-f8a2a27f8bf7} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39520) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:50.701143 [ 21834 ] {9fbc6118-2d76-43c6-8697-f8a2a27f8bf7} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.265911 [ 3613 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_8_8_0_16 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:51.266732 [ 3613 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_8_8_0_16}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:51.298731 [ 3623 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_17 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:51.299449 [ 3623 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_17}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:51.335818 [ 21812 ] {4ff77371-a269-41b9-a854-b464e8dc4560} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39558) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.345044 [ 21812 ] {4ff77371-a269-41b9-a854-b464e8dc4560} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.408981 [ 21834 ] {98249df5-f3cb-4325-a3b6-c4830d64ace2} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39554) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.412276 [ 21834 ] {98249df5-f3cb-4325-a3b6-c4830d64ace2} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.517260 [ 21830 ] {080369c5-8ec2-4a8e-bba4-1233e6a1b6eb} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39576) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.530432 [ 21830 ] {080369c5-8ec2-4a8e-bba4-1233e6a1b6eb} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e462a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380a4fc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b311 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.629952 [ 21346 ] {50bccb7b-5f75-42ab-91eb-fc8b8ad9ca29} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39592) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.650569 [ 21346 ] {50bccb7b-5f75-42ab-91eb-fc8b8ad9ca29} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.773096 [ 21909 ] {bdb1106c-7e0d-4549-b7fa-208565874299} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39600) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.781081 [ 21909 ] {bdb1106c-7e0d-4549-b7fa-208565874299} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.862728 [ 21972 ] {4ed3b991-6e28-41a7-a186-51e76e73a613} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39622) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:51.871015 [ 21972 ] {4ed3b991-6e28-41a7-a186-51e76e73a613} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:52.135590 [ 21972 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39622, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 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&&) @ 0x00000000204c305f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204c0eb0 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c1e41 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ea7cd 6. DB::ReadBuffer::next() @ 0x00000000095b3aaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abb079e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 14. ? @ 0x00007f550c19fac3 15. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.182012 [ 21830 ] {d644129c-f79e-4681-ae81-c9b79a3e32f8} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39632) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:52.184509 [ 21830 ] {d644129c-f79e-4681-ae81-c9b79a3e32f8} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98936d 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>>*) @ 0x000000003326b42f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034ba11a3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bab56c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:45:52.185165 [ 21830 ] {d644129c-f79e-4681-ae81-c9b79a3e32f8} TCPHandler: Client has gone away. 2025.09.09 14:45:52.324281 [ 3618 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.325008 [ 3618 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_21}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.409298 [ 3615 ] {} 78dab2ae-fda4-4ec1-80d6-c167149e1dec::-4_3_3_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.409955 [ 3615 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {78dab2ae-fda4-4ec1-80d6-c167149e1dec::-4_3_3_0_21}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.438753 [ 3613 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_3_3_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/5f4/5f468197-710e-44c8-b6bc-374ef3155aca/-4_3_3_0_16/ in table test_13.alter_table1 (5f468197-710e-44c8-b6bc-374ef3155aca) located on disk default of type local, from mark 0 with max_rows_to_read = 2611): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000307563fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c40 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521b1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073082e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073194f 11. DB::ReadBuffer::next() @ 0x00000000095b3aaf 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320df958 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320e3cae 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320e486d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032786242 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: 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 @ 0x0000000032639a70 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: 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>>>*) @ 0x0000000039c7447d 18. ./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>>&) @ 0x0000000039cccfd1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c99152 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cbc936 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb5073 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2fe06 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbf454 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21f50 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.439834 [ 3613 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_3_3_0_21}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/5f4/5f468197-710e-44c8-b6bc-374ef3155aca/-4_3_3_0_16/ in table test_13.alter_table1 (5f468197-710e-44c8-b6bc-374ef3155aca) located on disk default of type local, from mark 0 with max_rows_to_read = 2611): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000307563fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c40 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521b1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073082e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073194f 11. DB::ReadBuffer::next() @ 0x00000000095b3aaf 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320df958 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320e3cae 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320e486d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032786242 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: 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 @ 0x0000000032639a70 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: 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>>>*) @ 0x0000000039c7447d 18. ./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>>&) @ 0x0000000039cccfd1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c99152 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cbc936 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cb5073 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d2fe06 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfbf454 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d21f50 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf63ea5 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae49a9e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.460623 [ 3612 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.461486 [ 3612 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_21}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.544797 [ 3614 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_3_3_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.545563 [ 3614 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_3_3_0_21}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.590612 [ 3624 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.591363 [ 3624 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_21}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.594888 [ 3618 ] {} 78dab2ae-fda4-4ec1-80d6-c167149e1dec::-4_3_3_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.595663 [ 3618 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {78dab2ae-fda4-4ec1-80d6-c167149e1dec::-4_3_3_0_21}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.667940 [ 3618 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {099aa52d-ff08-48bf-87ed-79cf97f266be::202509_1_169_112}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009cb0d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x00000000200978df 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7e39f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011a21f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3aa5f2 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a73f4 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 17. ? @ 0x00007f550c19fac3 18. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.756507 [ 3626 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_3_3_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.761052 [ 3626 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_3_3_0_21}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.762313 [ 3620 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:52.763158 [ 3620 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_0_0_0_21}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:53.044486 [ 3611 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-5_0_0_0_26 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=737). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./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) @ 0x0000000034f6751a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000039e6bd36 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e69796 11. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e54926 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0075fe 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a003d6c 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:53.044602 [ 3619 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_2_2_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=776, jobs=754). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./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) @ 0x0000000034f6751a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000039e6bd36 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e69796 11. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e54926 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0075fe 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a003d6c 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:53.045863 [ 3611 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-5_0_0_0_26}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=737). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./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) @ 0x0000000034f6751a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000039e6bd36 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e69796 11. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e54926 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0075fe 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a003d6c 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:53.046482 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_2_2_0_21}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=776, jobs=754). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./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) @ 0x0000000034f6751a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000039e6bd36 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e69796 11. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e54926 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0075fe 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a003d6c 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 22. ? @ 0x00007f550c19fac3 23. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:53.135536 [ 3625 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-4_3_3_0_21 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:53.136342 [ 3625 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-4_3_3_0_21}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:53.317353 [ 3622 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-5_0_0_0_26 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:53.318388 [ 3622 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-5_0_0_0_26}: 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:54.735854 [ 3616 ] {} test_13.alter_table0 (ReplicatedMergeTreeQueue): Mutation with version 13 not found in partition ID 9 (trying to mutate part 9_4_4_0) 2025.09.09 14:45:54.735854 [ 3619 ] {} test_13.alter_table1 (ReplicatedMergeTreeQueue): Mutation with version 13 not found in partition ID 9 (trying to mutate part 9_4_4_0) 2025.09.09 14:45:55.030285 [ 3625 ] {} 5f468197-710e-44c8-b6bc-374ef3155aca::-1_15_15_0_33 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:55.030726 [ 3625 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f468197-710e-44c8-b6bc-374ef3155aca::-1_15_15_0_33}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:45:55.048907 [ 3614 ] {} test_13.alter_table1 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -1 (trying to mutate part -1_15_15_0 to 33) 2025.09.09 14:45:55.103081 [ 3615 ] {78dab2ae-fda4-4ec1-80d6-c167149e1dec::-1_15_15_0_33} 78dab2ae-fda4-4ec1-80d6-c167149e1dec::-1_15_15_0_33 (MutateFromLogEntryTask): Code: 40. DB::Exception: Part -1_15_15_0_33 from r2 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.09.09 14:45:55.656608 [ 21830 ] {608ac60a-eccf-43a1-a929-ab87c304f097} executeQuery: Code: 252. DB::Exception: Too many parts (3 with average size of 266.00 B) in table 'test_3.test (fcc4d939-2f92-4b57-afca-0beddeafd881)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39642) (comment: 02458_relax_too_many_parts.sql) (in query: INSERT INTO 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b5877 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397aee18 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a39c8db 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b803aec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b8022a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aecb260 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abd09ad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 21. ? @ 0x00007f550c19fac3 22. ? @ 0x00007f550c231850 2025.09.09 14:45:55.659122 [ 21830 ] {608ac60a-eccf-43a1-a929-ab87c304f097} TCPHandler: Code: 252. DB::Exception: Too many parts (3 with average size of 266.00 B) in table 'test_3.test (fcc4d939-2f92-4b57-afca-0beddeafd881)'. 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b5877 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397aee18 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a39c8db 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b803aec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b8022a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aecb260 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abd09ad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 21. ? @ 0x00007f550c19fac3 22. ? @ 0x00007f550c231850 2025.09.09 14:45:55.871037 [ 21833 ] {6c09a528-ec09-4e24-8185-dfead08a3f5d} executeQuery: Code: 341. DB::Exception: Mutation 0000000015 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42996) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 MODIFY COLUMN h 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387472f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x0000000038928ea1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038921f48 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b489 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:45:55.874028 [ 21833 ] {6c09a528-ec09-4e24-8185-dfead08a3f5d} TCPHandler: Code: 341. DB::Exception: Mutation 0000000015 was killed, manually removed or table was dropped. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083be10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000387472f6 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x0000000038928ea1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038921f48 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003485b489 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x00000000348536f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:45:55.874964 [ 21833 ] {6c09a528-ec09-4e24-8185-dfead08a3f5d} TCPHandler: Client has gone away. 2025.09.09 14:45:56.314882 [ 21830 ] {0c8426ee-17f2-44e2-ba56-c84aef8d5fe7} executeQuery: Code: 252. DB::Exception: Too many parts (3 with average size of 316.00 B) in table 'test_3.test (fcc4d939-2f92-4b57-afca-0beddeafd881)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39642) (comment: 02458_relax_too_many_parts.sql) (in query: INSERT INTO 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b5877 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397aee18 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a39c8db 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b803aec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b8022a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aecb260 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abd09ad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 21. ? @ 0x00007f550c19fac3 22. ? @ 0x00007f550c231850 2025.09.09 14:45:56.320305 [ 21830 ] {0c8426ee-17f2-44e2-ba56-c84aef8d5fe7} TCPHandler: Code: 252. DB::Exception: Too many parts (3 with average size of 316.00 B) in table 'test_3.test (fcc4d939-2f92-4b57-afca-0beddeafd881)'. 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000398b5877 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4585: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000397aee18 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:69: DB::MergeTreeSink::onStart() @ 0x000000003a39c8db 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b803aec 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b8037f6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b8022a2 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae7e344 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000003aecb260 13. ./build_docker/./src/Server/TCPHandler.cpp:1061: DB::TCPHandler::processInsertQuery() @ 0x000000003abd09ad 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2816 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 21. ? @ 0x00007f550c19fac3 22. ? @ 0x00007f550c231850 2025.09.09 14:46:00.407706 [ 21830 ] {ab84b773-0952-4956-b2ab-be80946a20fd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51810) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: SELECT count() - sum(is_readonly) FROM system.replicas WHERE database=currentDatabase() AND table LIKE 'alter_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:46:00.413429 [ 21830 ] {ab84b773-0952-4956-b2ab-be80946a20fd} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:46:06.673300 [ 21830 ] {f6d003c7-aad9-453c-a0be-9d7a6535190f} executeQuery: Code: 523. DB::Exception: There is no row policy `p1_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51832) (comment: 01296_create_row_policy_in_current_database.sql) (in query: DROP POLICY p1_01296 ON db_01296.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:06.675631 [ 21830 ] {f6d003c7-aad9-453c-a0be-9d7a6535190f} TCPHandler: Code: 523. DB::Exception: There is no row policy `p1_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.681116 [ 21830 ] {b21ad005-cbe5-4608-9caa-6ec1592ac7bb} executeQuery: Code: 523. DB::Exception: There is no row policy `p1_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51832) (comment: 01296_create_row_policy_in_current_database.sql) (in query: DROP POLICY p1_01296 ON db_01296.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.682842 [ 21830 ] {b21ad005-cbe5-4608-9caa-6ec1592ac7bb} TCPHandler: Code: 523. DB::Exception: There is no row policy `p1_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.703498 [ 21830 ] {11e7a8d8-38f8-48e6-94c0-e4b87c2df4b6} executeQuery: Code: 523. DB::Exception: There is no row policy `p2_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51832) (comment: 01296_create_row_policy_in_current_database.sql) (in query: DROP POLICY p2_01296 ON db_01296.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.705235 [ 21830 ] {11e7a8d8-38f8-48e6-94c0-e4b87c2df4b6} TCPHandler: Code: 523. DB::Exception: There is no row policy `p2_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.732431 [ 21830 ] {46dec63c-32de-45ee-82ad-b91bd3bba397} executeQuery: Code: 523. DB::Exception: There is no row policy `p3_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51832) (comment: 01296_create_row_policy_in_current_database.sql) (in query: DROP POLICY p3_01296 ON db_01296.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.734103 [ 21830 ] {46dec63c-32de-45ee-82ad-b91bd3bba397} TCPHandler: Code: 523. DB::Exception: There is no row policy `p3_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.748160 [ 21830 ] {e98a7a8c-e05b-41e0-a779-d07f2bef148f} executeQuery: Code: 523. DB::Exception: There is no row policy `p3_01296 ON db_01296.table2` in user directories. (UNKNOWN_ROW_POLICY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51832) (comment: 01296_create_row_policy_in_current_database.sql) (in query: DROP POLICY p3_01296 ON db_01296.table2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.749646 [ 21830 ] {e98a7a8c-e05b-41e0-a779-d07f2bef148f} TCPHandler: Code: 523. DB::Exception: There is no row policy `p3_01296 ON db_01296.table2` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.854913 [ 21830 ] {c0e34092-ffee-4a81-9d53-b3109dfe0354} executeQuery: Code: 523. DB::Exception: There is no row policy `p4_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51832) (comment: 01296_create_row_policy_in_current_database.sql) (in query: DROP POLICY p4_01296 ON db_01296.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.858609 [ 21830 ] {c0e34092-ffee-4a81-9d53-b3109dfe0354} TCPHandler: Code: 523. DB::Exception: There is no row policy `p4_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.963430 [ 21830 ] {619d6d72-e5ce-4370-b7ca-981b95f9d9b8} executeQuery: Code: 523. DB::Exception: There is no row policy `p5_01296 ON db_01296.table2` in user directories. (UNKNOWN_ROW_POLICY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51832) (comment: 01296_create_row_policy_in_current_database.sql) (in query: DROP POLICY p5_01296 ON db_01296.table2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:07.965231 [ 21830 ] {619d6d72-e5ce-4370-b7ca-981b95f9d9b8} TCPHandler: Code: 523. DB::Exception: There is no row policy `p5_01296 ON db_01296.table2` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313fa810 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x00000000313fade9 5. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x0000000036e934b2 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterDropAccessEntityQuery::execute() @ 0x0000000036e91bf0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:08.929789 [ 21346 ] {9c0a4557-8f97-4dc3-b035-fed4d7645cf5} executeQuery: Code: 497. DB::Exception: user_02916_dictionary_access_test_3: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict_02916_dictionary_access_test_3. (ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49882) (comment: 02916_dictionary_access.sh) (in query: SELECT * FROM dictionary(dict_02916_dictionary_access_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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e0e1b 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312e07d3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df2f7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296051 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337bb84f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000003372c70f 9. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038249683 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038160211 11. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:46:08.933910 [ 21346 ] {9c0a4557-8f97-4dc3-b035-fed4d7645cf5} TCPHandler: Code: 497. DB::Exception: user_02916_dictionary_access_test_3: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict_02916_dictionary_access_test_3. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e0e1b 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312e07d3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df2f7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296051 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337bb84f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000003372c70f 9. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038249683 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038160211 11. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d73702 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d5a334 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfeb7e 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cf0b52 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce9412 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a6f31 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:46:11.433661 [ 21830 ] {4e8a47c3-5aab-4cad-b3f1-1d588f05f4da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49912) (comment: 02013_bloom_filter_hasAll.sql) (in query: INSERT INTO bftest (k, x) SELECT number, arrayMap(i->rand64()%565656, range(10)) 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./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*) @ 0x000000003ae7acd9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:46:11.439590 [ 21830 ] {4e8a47c3-5aab-4cad-b3f1-1d588f05f4da} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./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*) @ 0x000000003ae7acd9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:46:11.885251 [ 21346 ] {8534b929-427f-45db-9876-3eb73e99a12b} executeQuery: Code: 497. DB::Exception: user_02916_dictionary_access_test_3: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict_02916_dictionary_access_test_3: In scope SELECT dictGet(dict_02916_dictionary_access_test_3, 'value', 1). (ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49904) (comment: 02916_dictionary_access.sh) (in query: SELECT dictGet(dict_02916_dictionary_access_test_3, 'value', 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e0e1b 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312e07d3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df2f7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296051 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337bb84f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000003372c70f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000096af5ca 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a41e4 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 2025.09.09 14:46:11.889446 [ 21346 ] {8534b929-427f-45db-9876-3eb73e99a12b} TCPHandler: Code: 497. DB::Exception: user_02916_dictionary_access_test_3: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict_02916_dictionary_access_test_3: In scope SELECT dictGet(dict_02916_dictionary_access_test_3, 'value', 1). (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e0e1b 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000312e07d3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df2f7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296051 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337bb84f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000003372c70f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000096af5ca 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a41e4 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837a9c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d28bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fde10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fefaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a79f2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033446566 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000334437f1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334dd540 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342e342 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 2025.09.09 14:46:13.874176 [ 21830 ] {26d5e216-5369-4524-bf2b-371b3be90b56} executeQuery: Code: 57. DB::Exception: Table test_13.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49924) (comment: 02841_not_ready_set_constraints.sql) (in query: CREATE TABLE t2 (`conversation` UInt64, CONSTRAINT constraint_conversation CHECK conversation IN (SELECT id FROM t1)) ENGINE = MergeTree ORDER BY conversation SETTINGS index_granularity = 8568, 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 = 478380931, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27876603, merge_max_block_size = 15204, old_parts_lifetime = 121., 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 = 6779767062, index_granularity_bytes = 24874878, concurrent_part_removal_threshold = 72, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 42457, primary_key_compress_block_size = 82976), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:13.877165 [ 21830 ] {26d5e216-5369-4524-bf2b-371b3be90b56} TCPHandler: Code: 57. DB::Exception: Table test_13.t2 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:13.955009 [ 21346 ] {7c0092ac-7e51-41e5-952b-9e9ff0848133} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49944) (comment: 01825_type_json_order_by.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:46:13.958614 [ 21346 ] {7c0092ac-7e51-41e5-952b-9e9ff0848133} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:46:16.411787 [ 21346 ] {ee792ee4-e250-4a78-aaf8-32ee95e1ec38} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1) 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:16.413792 [ 21346 ] {ee792ee4-e250-4a78-aaf8-32ee95e1ec38} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:16.433880 [ 21346 ] {84f1d05b-bdc2-46d4-a99c-b7397c15215f} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1) SAMPLE 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:16.436037 [ 21346 ] {84f1d05b-bdc2-46d4-a99c-b7397c15215f} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:16.454665 [ 21346 ] {03d10d3a-fcdd-44c5-8773-a36b93f6fcc5} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1) FINAL SAMPLE 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:16.456557 [ 21346 ] {03d10d3a-fcdd-44c5-8773-a36b93f6fcc5} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.561523 [ 21346 ] {d05ae7e6-1cda-4606-9bdb-a6d0b2fb1e23} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.563512 [ 21346 ] {d05ae7e6-1cda-4606-9bdb-a6d0b2fb1e23} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.587447 [ 21346 ] {4dcce033-46ef-4967-9830-e5ad521c46c2} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery SAMPLE 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.599434 [ 21346 ] {4dcce033-46ef-4967-9830-e5ad521c46c2} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.621400 [ 21346 ] {84711818-f842-4e38-aa8a-5a1aa84dbc7e} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.623452 [ 21346 ] {84711818-f842-4e38-aa8a-5a1aa84dbc7e} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.642677 [ 21346 ] {6463d084-0cae-42a8-8c8c-67a853e606b8} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.644115 [ 21346 ] {6463d084-0cae-42a8-8c8c-67a853e606b8} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.662687 [ 21346 ] {6ec29bb2-52ca-45bb-a708-459e73b92322} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) SAMPLE 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.664369 [ 21346 ] {6ec29bb2-52ca-45bb-a708-459e73b92322} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.729465 [ 21346 ] {7c0e4b97-c134-4918-8a06-3e8f89ebb001} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) FINAL SAMPLE 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.731200 [ 21346 ] {7c0e4b97-c134-4918-8a06-3e8f89ebb001} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:847: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000333a596b 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382dca 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000003338d5a7 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000033382c2d 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003338175c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce59f0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.755662 [ 21346 ] {5f7034c2-906c-47e3-a8bc-f6c6fec6f2ee} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.757491 [ 21346 ] {5f7034c2-906c-47e3-a8bc-f6c6fec6f2ee} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.776993 [ 21346 ] {6f75f3cb-4f14-4380-ab9b-5fc3eb81a032} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery SAMPLE 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.778498 [ 21346 ] {6f75f3cb-4f14-4380-ab9b-5fc3eb81a032} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.854053 [ 21346 ] {2bc41d88-3df5-41cf-b711-6ebf809ee39b} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49962) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:17.855451 [ 21346 ] {2bc41d88-3df5-41cf-b711-6ebf809ee39b} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4250: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e252e 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342dfcd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003342ad46 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000033429239 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034975c59 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&) @ 0x0000000034ce7524 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cdeb6e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034ce9f95 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034ce9af3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b8520c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a64d7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 23. ? @ 0x00007f550c19fac3 24. ? @ 0x00007f550c231850 2025.09.09 14:46:24.404070 [ 21830 ] {ff063c28-c552-4fc9-b7d3-7255594bb339} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=804, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49948) (comment: 00909_ngram_distance.sql) (in query: select round(1000 * ngramDistanceCaseInsensitiveUTF8('', materialize(''))) = round(1000 * ngramDistanceCaseInsensitiveUTF8(materialize(''), '')) from system.numbers limit 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:24.409072 [ 21830 ] {ff063c28-c552-4fc9-b7d3-7255594bb339} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=804, jobs=739). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:25.398726 [ 21830 ] {1e3f323d-9269-45c1-8f34-6cc5a2d2e78c} 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.10505.altinitytest (altinity build)) (from [::1]:41884) (comment: 01276_alter_rename_column_materialized_expr.sql) (in query: CREATE TABLE table_for_rename ( date Date, key UInt64, value1 String, value2 String, value3 String MATERIALIZED concat(value1, ' + ', value2) ) ENGINE = MergeTree() 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:46:25.402493 [ 21830 ] {1e3f323d-9269-45c1-8f34-6cc5a2d2e78c} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396f134f 8. ./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>) @ 0x000000003a2c8e0a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.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>&&) @ 0x000000003a2c6f0f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2b5f23 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7af9a 12. ./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 @ 0x00000000382f6666 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d752c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 25. ? @ 0x00007f550c19fac3 26. ? @ 0x00007f550c231850 2025.09.09 14:46:32.469339 [ 21951 ] {4cee8c8e-727f-493e-a974-b12e9288eb5c} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 8 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_3_data1.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54028) (comment: 02305_schema_inference_with_globs.sh) (in query: desc file('02305_schema_inference_with_globs_test_3_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=8, input_format_json_infer_incomplete_types_as_strings=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:46:32.471732 [ 21951 ] {4cee8c8e-727f-493e-a974-b12e9288eb5c} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 8 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_3_data1.jsonl). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beafbad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9acc7 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:46:33.570473 [ 21909 ] {a28db8bd-3195-4e6e-ad3a-5f8ece27a99e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=804, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53996) (comment: 02007_test_any_all_operators.sql) (in query: select 11 <= all (select number from numbers(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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:33.572778 [ 21909 ] {a28db8bd-3195-4e6e-ad3a-5f8ece27a99e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=804, jobs=739). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:34.868602 [ 21951 ] {f937a270-6fcf-4483-acad-bdb47409fbd4} executeQuery: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 6 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_3_data2.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54030) (comment: 02305_schema_inference_with_globs.sh) (in query: desc file('02305_schema_inference_with_globs_test_3_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=16, input_format_json_infer_incomplete_types_as_strings=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9af32 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:46:34.872458 [ 21951 ] {f937a270-6fcf-4483-acad-bdb47409fbd4} TCPHandler: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 6 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_3_data2.jsonl). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9af32 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:46:35.783836 [ 21951 ] {d7fe984a-7b7b-4d5b-8703-8d8c620fc1dc} executeQuery: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 4 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_3_data3.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54046) (comment: 02305_schema_inference_with_globs.sh) (in query: desc file('02305_schema_inference_with_globs_test_3_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=24, input_format_json_infer_incomplete_types_as_strings=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9af32 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:46:35.786535 [ 21951 ] {d7fe984a-7b7b-4d5b-8703-8d8c620fc1dc} TCPHandler: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 4 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.8.14.10505.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_3_data3.jsonl). (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842050a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9af32 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad9f455 6. ./build_docker/./src/Storages/StorageFile.cpp:959: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000038309f12 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&) @ 0x000000003830b7cf 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe391c0 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359e1541 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359de865 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 20. ? @ 0x00007f550c19fac3 21. ? @ 0x00007f550c231850 2025.09.09 14:46:40.167042 [ 3417 ] {} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ef57d 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339bf518 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339c056e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339e149f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199e372 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a9693 12. ./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*) @ 0x00000000319ab32f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 15. ? @ 0x00007f550c19fac3 16. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:46:44.665951 [ 21909 ] {58ad4d14-3e9f-42bb-8259-17845120cead} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 256.00 GiB (attempt to allocate chunk of 274878520072 bytes), maximum: 9.31 GiB.: while executing 'FUNCTION repeat(toString(__table2.number) :: 0, 1000000_UInt32 :: 1) -> repeat(toString(__table2.number), 1000000_UInt32) String : 3'. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40270) (comment: 01586_columns_pruning.sql) (in query: -- Unneeded column cannot be removed from subquery and the query is out of memory SELECT count() FROM (SELECT number, groupArray(repeat(toString(number), 1000000)) AS agg FROM numbers(1000000) GROUP BY number HAVING notEmpty(agg));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff78764 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083a8e10 9. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001bd9ab9b 10. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bd914ee 11. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d27db 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a19dfe 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8057c4 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acedc4 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae403cb 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 27. ? @ 0x00007f550c19fac3 28. ? @ 0x00007f550c231850 2025.09.09 14:46:44.670210 [ 21909 ] {58ad4d14-3e9f-42bb-8259-17845120cead} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 256.00 GiB (attempt to allocate chunk of 274878520072 bytes), maximum: 9.31 GiB.: while executing 'FUNCTION repeat(toString(__table2.number) :: 0, 1000000_UInt32 :: 1) -> repeat(toString(__table2.number), 1000000_UInt32) String : 3'. (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: 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>&&) @ 0x000000002009cd50 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009b012 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3f2 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7dbdd 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff78764 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083a8e10 9. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001bd9ab9b 10. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bd914ee 11. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d27db 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ff2ca 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b60109f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b606e7e 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a19dfe 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b8057c4 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acedc4 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae403cb 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 27. ? @ 0x00007f550c19fac3 28. ? @ 0x00007f550c231850 2025.09.09 14:46:48.640538 [ 21909 ] {7895fde9-986a-4e74-8754-2011a35577db} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44700) (comment: 00727_concat.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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:46:48.645614 [ 21909 ] {7895fde9-986a-4e74-8754-2011a35577db} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b92aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c529 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159abab 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b29b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000003374c532 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e6b2f4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:46:49.981594 [ 21909 ] {550fa949-412c-451f-95b5-48d52213dfec} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44702) (comment: 01076_predicate_optimizer_with_view.sql) (in query: CREATE TABLE test(date Date, id Int8, name String, value Int64) ENGINE = MergeTree(date, (id, date), 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:49.983296 [ 21909 ] {550fa949-412c-451f-95b5-48d52213dfec} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838166d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348de6b4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c264a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea356 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003589b09d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abb2538 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:46:54.504661 [ 21909 ] {88604f33-c3f8-4666-9392-07cb32ef4707} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44726) (comment: 02376_arrow_dict_with_string.sql) (in query: select * from file(02376_data.arrow);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:46:54.508381 [ 21909 ] {88604f33-c3f8-4666-9392-07cb32ef4707} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:47:06.358370 [ 21909 ] {dc90b919-447f-42db-adae-dad71e81e25d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=804, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42374) (comment: 03039_recursive_cte_postgres_5.sql) (in query: -- forward reference OK WITH RECURSIVE x AS (SELECT * FROM y UNION ALL SELECT id+1 FROM x WHERE id < 5), y AS (SELECT 1 AS id) SELECT * FROM x 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:47:06.365806 [ 21909 ] {dc90b919-447f-42db-adae-dad71e81e25d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=804, jobs=739). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aeb950c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aebab8b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abd4c85 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abb2878 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac07751 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 16. ? @ 0x00007f550c19fac3 17. ? @ 0x00007f550c231850 2025.09.09 14:47:11.840564 [ 16153 ] {b3a5f0f6-8ffc-4e6f-89e8-3134d7f97b3f} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50414) (in query: select 1 as x format TSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3a05c8 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aed9272 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 15. ./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&)>) @ 0x00000000358b9e13 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 2025.09.09 14:47:11.846573 [ 16153 ] {b3a5f0f6-8ffc-4e6f-89e8-3134d7f97b3f} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b39d8b7 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b39a4c5 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3a05c8 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aed9272 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aeb072d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f666 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d723 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae79b5f 15. ./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&)>) @ 0x00000000358b9e13 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 24. ? @ 0x00007f550c19fac3 25. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:47:13.340696 [ 21909 ] {e1ffef6e-ab6c-420c-a105-548464e40a4b} 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.10505.altinitytest (altinity build)) (from [::1]:47592) (comment: 02456_aggregate_state_conversion.sql) (in query: SELECT hex(CAST(x, 'AggregateFunction(sum, Decimal(50, 10))')) FROM (SELECT arrayReduce('sumState', [toDecimal256('0.0000010.000001', 10)]) AS x) GROUP 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:47:13.349676 [ 21909 ] {e1ffef6e-ab6c-420c-a105-548464e40a4b} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dd68b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae7d635 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d188 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 12. ? @ 0x00007f550c19fac3 13. ? @ 0x00007f550c231850 2025.09.09 14:47:40.730208 [ 21951 ] {2570a59e-45ca-4d5c-824b-d1ae062a6373} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.004664478 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40264) (comment: 02231_buffer_aggregate_states_leak.sql) (in query: insert into in_02231 select * from numbers(5e6) settings max_memory_usage='400Mi', max_threads=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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322c504d 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322c30c8 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003501755c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae7d9ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d28a 8. ./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*) @ 0x000000003ae7acd9 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 11. ? @ 0x00007f550c19fac3 12. ? @ 0x00007f550c231850 2025.09.09 14:47:41.540668 [ 21951 ] {2570a59e-45ca-4d5c-824b-d1ae062a6373} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.004664478 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322c504d 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322c30c8 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003501755c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae7d9ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d28a 8. ./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*) @ 0x000000003ae7acd9 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 11. ? @ 0x00007f550c19fac3 12. ? @ 0x00007f550c231850 2025.09.09 14:48:52.649149 [ 22928 ] {c9fb1295-29b5-4ee1-baa2-3a0c15d10393} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.182709011 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58778) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322c504d 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322c30c8 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003501755c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae7d9ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d28a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 11. ? @ 0x00007f550c19fac3 12. ? @ 0x00007f550c231850 2025.09.09 14:48:52.651418 [ 22928 ] {c9fb1295-29b5-4ee1-baa2-3a0c15d10393} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.182709011 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322c504d 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322c30c8 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003501755c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae7d9ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae7d28a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aebd61d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 11. ? @ 0x00007f550c19fac3 12. ? @ 0x00007f550c231850 2025.09.09 14:48:54.526945 [ 21837 ] {3fb54148-cc19-435f-aca4-e362c8c0d087} 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.10505.altinitytest (altinity build)) (from [::1]:33672) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000329b1012 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000329b0928 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000329af884 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034889522 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 2025.09.09 14:48:54.530420 [ 21837 ] {3fb54148-cc19-435f-aca4-e362c8c0d087} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000329b1012 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000329b0928 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000329af884 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034889522 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348ea326 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a9715 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&)>) @ 0x00000000358b6f77 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa01591 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa0d9a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac33f01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000406087a0 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000406096e0 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404eb475 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404e7e4e 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404e4d11 18. ? @ 0x00007f550c19fac3 19. ? @ 0x00007f550c231850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:49:04.799392 [ 2874 ] {} Application: Closed all listening sockets. Waiting for 16 outstanding connections. 2025.09.09 14:49:09.707454 [ 2874 ] {} Application: Closed connections. But 16 remain. Tip: To increase wait time add to config: 60 2025.09.09 14:49:09.708316 [ 2874 ] {} Application: Will shutdown forcefully. 2025.09.09 14:49:13.028356 [ 22984 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.09.09 14:49:13.059765 [ 22984 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.09.09 14:49:13.066565 [ 22984 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.09 14:49:13.068928 [ 22984 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.09 14:49:23.792964 [ 22984 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.09 14:49:23.802076 [ 22984 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.09 14:49:23.802166 [ 22984 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.09 14:49:23.853708 [ 23622 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.09 14:49:27.977628 [ 22984 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.09 14:49:28.609380 [ 22984 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.09.09 14:49:28.860872 [ 22984 ] {} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.09.09 14:49:28.861298 [ 22984 ] {} TablesLoader: Tables test_3.test_dictionary3, test_3.test_dictionary0 depend on test_db.table_01, but seems like that does not exist. Will ignore it and try to load existing tables 2025.09.09 14:49:28.861494 [ 22984 ] {} TablesLoader: Tables test_13.dist_01270 depend on default.key, but seems like that does not exist. Will ignore it and try to load existing tables 2025.09.09 14:49:29.667924 [ 23795 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e5334 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d3809 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d54b4 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x0000000033981379 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::DDLWorker::startup() @ 0x000000003393081a 8. ./src/Common/SharedMutexHelper.h:91: void std::__function::__policy_invoker const&)>::__call_impl>, std::vector, std::allocator>> const&)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000337b4572 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000020712266 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020713c80 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 16. ? @ 0x00007fb520975ac3 17. ? @ 0x00007fb520a07850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:49:30.007581 [ 22994 ] {df4854e4-3562-47ca-afd9-2f5e326b3a4c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45044) (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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f877 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007fb520975ac3 15. ? @ 0x00007fb520a07850 2025.09.09 14:49:30.009783 [ 22994 ] {df4854e4-3562-47ca-afd9-2f5e326b3a4c} 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae8168c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae7f877 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae81e78 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 14. ? @ 0x00007fb520975ac3 15. ? @ 0x00007fb520a07850 2025.09.09 14:49:45.861928 [ 23656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7aa30d62-5bef-4999-be1c-ed4828d746b7::202509_1_166_67}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, 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) @ 0x00000000403c8469 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020033393 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837cb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202eb774 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dbca9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202db52a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039bf7943 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039bec982 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039bebdf9 9. ./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) @ 0x0000000039c6fa68 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: 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&&) @ 0x0000000039982117 11. ./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 @ 0x000000003997a450 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: 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) @ 0x0000000039cfbd24 13. ./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&) @ 0x0000000039d064b9 14. ./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) @ 0x0000000039d02726 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039619344 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960c07d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000039623e80 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039638f40 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a741d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396946de 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396964a8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003969d7bf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d8713 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202ead46 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202eaaff 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d157d 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e3ac4 28. ? @ 0x00007fb520975ac3 29. ? @ 0x00007fb520a07850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:49:52.703671 [ 23636 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled